Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 

A

AbstractAddConfigMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
Base implementation for dynamic add***Config methods.
AbstractAddConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.AbstractAddConfigMessageTask
 
AbstractAddressMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
AbstractAddressMessageTask
AbstractAddressMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractAddressMessageTask
 
AbstractAggregator<I,E,R> - Class in com.hazelcast.aggregation.impl
Abstract class providing convenience for concrete implementations of an Aggregator It provides built-in extraction capabilities that may be used in the accumulation phase.
AbstractAggregator() - Constructor for class com.hazelcast.aggregation.impl.AbstractAggregator
 
AbstractAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.AbstractAggregator
 
AbstractAllPartitionsMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
 
AbstractAllPartitionsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractAllPartitionsMessageTask
 
AbstractAtomicLongOp - Class in com.hazelcast.cp.internal.datastructures.atomiclong.operation
Base class for operations of Raft-based atomic long
AbstractAtomicRefOp - Class in com.hazelcast.cp.internal.datastructures.atomicref.operation
Base class for operations of Raft-based atomic reference
AbstractAtomicRefOp() - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.operation.AbstractAtomicRefOp
 
AbstractBackupAwareMultiMapOperation - Class in com.hazelcast.multimap.impl.operations
 
AbstractBackupAwareMultiMapOperation() - Constructor for class com.hazelcast.multimap.impl.operations.AbstractBackupAwareMultiMapOperation
 
AbstractBackupAwareMultiMapOperation(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.AbstractBackupAwareMultiMapOperation
 
AbstractBackupAwareSchedulerOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
AbstractBaseNearCacheInvalidationListener - Class in com.hazelcast.internal.nearcache.impl.invalidation
 
AbstractBaseNearCacheInvalidationListener(UUID, long) - Constructor for class com.hazelcast.internal.nearcache.impl.invalidation.AbstractBaseNearCacheInvalidationListener
 
AbstractBaseReplicatedRecordStore<K,V> - Class in com.hazelcast.replicatedmap.impl.record
Internal base class to encapsulate the internals from the interface methods of ReplicatedRecordStore
AbstractBaseReplicatedRecordStore(String, ReplicatedMapService, int) - Constructor for class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
AbstractBasicConfig<T extends AbstractBasicConfig> - Class in com.hazelcast.config
Provides a basic configuration for a split-brain aware data structure.
AbstractBasicConfig() - Constructor for class com.hazelcast.config.AbstractBasicConfig
 
AbstractBasicConfig(String) - Constructor for class com.hazelcast.config.AbstractBasicConfig
 
AbstractBasicConfig(AbstractBasicConfig) - Constructor for class com.hazelcast.config.AbstractBasicConfig
 
AbstractBlockingService<W extends WaitKey,R extends BlockingResource<W>,RR extends ResourceRegistry<W,R>> - Class in com.hazelcast.cp.internal.datastructures.spi.blocking
Base class for services that maintain blocking resources.
AbstractBlockingService(NodeEngine) - Constructor for class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
AbstractBuilder() - Constructor for class com.hazelcast.internal.serialization.impl.SerializationServiceV1.AbstractBuilder
 
AbstractCacheConfig<K,V> - Class in com.hazelcast.config
Base class for CacheConfig
AbstractCacheConfig() - Constructor for class com.hazelcast.config.AbstractCacheConfig
 
AbstractCacheConfig(CompleteConfiguration<K, V>) - Constructor for class com.hazelcast.config.AbstractCacheConfig
 
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,E> - 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
 
AbstractCacheService - Class in com.hazelcast.cache.impl
 
AbstractCacheService() - Constructor for class com.hazelcast.cache.impl.AbstractCacheService
 
AbstractCacheSyncListenerCompleter - Class in com.hazelcast.cache.impl
Abstract CacheSyncListenerCompleter implementation which provides storage and management of countdown latches and cache entry listener registrations.
AbstractCacheSyncListenerCompleter() - Constructor for class com.hazelcast.cache.impl.AbstractCacheSyncListenerCompleter
 
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
 
AbstractCallIdSequence - Class in com.hazelcast.spi.impl.sequence
A CallIdSequence that provides backpressure by taking the number of in-flight operations into account when before creating a new call-id.
AbstractCallIdSequence(int, ConcurrencyDetection) - Constructor for class com.hazelcast.spi.impl.sequence.AbstractCallIdSequence
 
AbstractCardinalityEstimatorOperation - Class in com.hazelcast.cardinality.impl.operations
 
AbstractChannel - Class in com.hazelcast.internal.networking
An abstract Channel implementation.
AbstractChannel(SocketChannel, boolean) - Constructor for class com.hazelcast.internal.networking.AbstractChannel
 
AbstractChannelInitializer - Class in com.hazelcast.internal.nio.tcp
A ChannelInitializer that runs on a member and used for unencrypted channels.
AbstractChannelInitializer(IOService, EndpointConfig) - Constructor for class com.hazelcast.internal.nio.tcp.AbstractChannelInitializer
 
AbstractClientInvocationService - Class in com.hazelcast.client.impl.spi.impl
 
AbstractClientInvocationService(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.impl.spi.impl.AbstractClientInvocationService
 
AbstractClientListenerService - Class in com.hazelcast.client.impl.spi.impl.listener
 
AbstractClientOperation - Class in com.hazelcast.client.impl.operations
 
AbstractClientOperation() - Constructor for class com.hazelcast.client.impl.operations.AbstractClientOperation
 
AbstractClusterWideIterator<K,V> - Class in com.hazelcast.cache.impl
AbstractClusterWideIterator provides the core iterator functionality shared by its descendants.
AbstractClusterWideIterator(ICacheInternal<K, V>, int, int, boolean) - Constructor for class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
AbstractCollectionMergingValueImpl<V extends Collection,T extends AbstractCollectionMergingValueImpl<V,T>> - Class in com.hazelcast.spi.impl.merge
Implementation of MergingValue for data structures with collections.
AbstractCollectionMergingValueImpl() - Constructor for class com.hazelcast.spi.impl.merge.AbstractCollectionMergingValueImpl
 
AbstractCollectionMergingValueImpl(SerializationService) - Constructor for class com.hazelcast.spi.impl.merge.AbstractCollectionMergingValueImpl
 
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
 
AbstractConfigLocator - Class in com.hazelcast.config
Abstract base class for config locators.
AbstractConfigLocator() - Constructor for class com.hazelcast.config.AbstractConfigLocator
 
AbstractContainerCollector<C> - Class in com.hazelcast.spi.impl.merge
Collects non-threadsafe containers for SplitBrainHandlerService capable data structures.
AbstractContainerCollector(NodeEngine) - Constructor for class com.hazelcast.spi.impl.merge.AbstractContainerCollector
 
AbstractContainerCollector.EmptyIterator - Class in com.hazelcast.spi.impl.merge
Empty iterator for AbstractContainerCollector.containerIterator(int) calls, if the requested partition is empty.
AbstractContainerMerger<C,V,T extends MergingValue<V>> - Class in com.hazelcast.spi.impl.merge
Merges data structures which have been collected via an AbstractContainerCollector.
AbstractContainerMerger(AbstractContainerCollector<C>, NodeEngine) - Constructor for class com.hazelcast.spi.impl.merge.AbstractContainerMerger
 
AbstractCountDownLatchOp - Class in com.hazelcast.cp.internal.datastructures.countdownlatch.operation
Base class for operations of Raft-based count down latch
AbstractCountDownLatchOp() - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.AbstractCountDownLatchOp
 
AbstractCPMessageTask<P> - Class in com.hazelcast.cp.internal.client
 
AbstractCPMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.client.AbstractCPMessageTask
 
AbstractCPMigrationAwareService - Class in com.hazelcast.cp.internal.datastructures.spi
Abstract MigrationAwareService implementation to provide partition migration support for CP data structures unsafe mode.
AbstractCPMigrationAwareService(NodeEngine) - Constructor for class com.hazelcast.cp.internal.datastructures.spi.AbstractCPMigrationAwareService
 
AbstractCRDTReplicationOperation<T extends IdentifiedDataSerializable> - Class in com.hazelcast.internal.crdt
Base class for CRDT replication operations.
AbstractCRDTReplicationOperation() - Constructor for class com.hazelcast.internal.crdt.AbstractCRDTReplicationOperation
 
AbstractCRDTReplicationOperation(Map<String, T>) - Constructor for class com.hazelcast.internal.crdt.AbstractCRDTReplicationOperation
Constructs the replication operation.
AbstractCursor<T> - Class in com.hazelcast.map.impl.iterator
Base class for a cursor class holding a collection of items and the next position from which to resume fetching.
AbstractCursor() - Constructor for class com.hazelcast.map.impl.iterator.AbstractCursor
 
AbstractCursor(List<T>, int) - Constructor for class com.hazelcast.map.impl.iterator.AbstractCursor
 
AbstractDiscoveryStrategy - Class in com.hazelcast.spi.discovery
An common abstract superclass for DiscoveryStrategy implementations, offering convenient access to configuration properties (which may be overridden on the system's environment or JVM properties), as well as a ILogger instance.
AbstractDiscoveryStrategy(ILogger, Map<String, Comparable>) - Constructor for class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
 
AbstractDistributedObject<S extends RemoteService> - Class in com.hazelcast.spi.impl
Abstract DistributedObject implementation.
AbstractDistributedObject(NodeEngine, S) - Constructor for class com.hazelcast.spi.impl.AbstractDistributedObject
 
AbstractDomConfigProcessor - Class in com.hazelcast.config
Base class of the config processors working from W3C DOM objects
AbstractDomConfigProcessor(boolean) - Constructor for class com.hazelcast.config.AbstractDomConfigProcessor
 
AbstractDynamicConfigOperation - Class in com.hazelcast.internal.dynamicconfig
 
AbstractDynamicConfigOperation() - Constructor for class com.hazelcast.internal.dynamicconfig.AbstractDynamicConfigOperation
 
AbstractEventBase - Class in com.hazelcast.internal.management.events
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheAddEntryListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheAddInvalidationListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheAddNearCacheInvalidationListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheAddPartitionLostListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientAddDistributedObjectListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientAddMembershipListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionLostListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientLocalBackupListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.ContinuousQueryAddListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListAddListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyWithPredicateCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerWithPredicateCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheEntryListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheInvalidationListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddPartitionLostListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerToKeyCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueAddListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyWithPredicateCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerWithPredicateCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddNearCacheEntryListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetAddListenerCodec.AbstractEventHandler
 
AbstractEventHandler() - Constructor for class com.hazelcast.client.impl.protocol.codec.TopicAddMessageListenerCodec.AbstractEventHandler
 
AbstractEvictableRecordStore - Class in com.hazelcast.map.impl.recordstore
Contains eviction specific functionality.
AbstractEvictableRecordStore(MapContainer, int) - Constructor for class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
AbstractEvictableRecordStore.ReadOnlyRecordIterator - Class in com.hazelcast.map.impl.recordstore
Read only iterator.
AbstractExecutorThreadFactory - Class in com.hazelcast.internal.util.executor
 
AbstractExecutorThreadFactory(ClassLoader) - Constructor for class com.hazelcast.internal.util.executor.AbstractExecutorThreadFactory
 
AbstractFencedLockProxy - Class in com.hazelcast.cp.internal.datastructures.lock.proxy
Implements proxy methods for Raft-based FencedLock API.
AbstractFencedLockProxy(AbstractProxySessionManager, RaftGroupId, String, String) - Constructor for class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
AbstractFilteringStrategy - Class in com.hazelcast.map.impl.event
A common abstract class to support implementations of filtering strategies.
AbstractFilteringStrategy(InternalSerializationService, MapServiceContext) - Constructor for class com.hazelcast.map.impl.event.AbstractFilteringStrategy
 
AbstractGetAllScheduledOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
AbstractGetAllScheduledOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.AbstractGetAllScheduledOperation
 
AbstractGetAllScheduledOperation(String) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.AbstractGetAllScheduledOperation
 
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
AbstractHazelcastCacheManager - Class in com.hazelcast.cache.impl
Abstract HazelcastCacheManager (also indirect CacheManager) implementation to provide shared functionality to server and client cache managers.
AbstractHazelcastCacheManager(CachingProvider, HazelcastInstance, URI, ClassLoader, Properties) - Constructor for class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
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
 
AbstractICacheEvent - Class in com.hazelcast.cache.impl.event
The abstract class for a JCache event ICacheEvent.
AbstractICacheEvent(Object, Member, int) - Constructor for class com.hazelcast.cache.impl.event.AbstractICacheEvent
Constructs a prototypical Cache Event.
AbstractIMapEvent - Class in com.hazelcast.map
The abstract class for a map event IMapEvent.
AbstractIMapEvent(Object, Member, int) - Constructor for class com.hazelcast.map.AbstractIMapEvent
Constructs a prototypical map Event.
AbstractIndex - Class in com.hazelcast.query.impl
Provides an abstract base for indexes.
AbstractIndex(IndexConfig, InternalSerializationService, Extractors, IndexCopyBehavior, PerIndexStats, StoreAdapter) - Constructor for class com.hazelcast.query.impl.AbstractIndex
 
AbstractIndexAwarePredicate<K,V> - Class in com.hazelcast.query.impl.predicates
 
AbstractIndexAwarePredicate() - Constructor for class com.hazelcast.query.impl.predicates.AbstractIndexAwarePredicate
 
AbstractIndexAwarePredicate(String) - Constructor for class com.hazelcast.query.impl.predicates.AbstractIndexAwarePredicate
 
AbstractInvocationFuture<V> - Class in com.hazelcast.spi.impl
Custom implementation of CompletableFuture.
AbstractInvocationFuture(ILogger) - Constructor for class com.hazelcast.spi.impl.AbstractInvocationFuture
 
AbstractInvocationFuture.AbstractBiNode<T,U,R> - Class in com.hazelcast.spi.impl
 
AbstractInvocationFuture.AbstractEitherNode<T,R> - Class in com.hazelcast.spi.impl
 
AbstractInvocationFuture.ApplyNode<V,R> - Class in com.hazelcast.spi.impl
 
AbstractInvocationFuture.ComposeNode<T,U> - Class in com.hazelcast.spi.impl
 
AbstractInvocationFuture.ExceptionallyNode<R> - Class in com.hazelcast.spi.impl
 
AbstractInvocationFuture.ExceptionalResult - Class in com.hazelcast.spi.impl
 
AbstractInvocationFuture.RunNode - Class in com.hazelcast.spi.impl
 
AbstractInvocationMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
 
AbstractInvocationMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractInvocationMessageTask
 
AbstractJoiner - Class in com.hazelcast.internal.cluster.impl
 
AbstractJoiner(Node) - Constructor for class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
AbstractJoinOperation - Class in com.hazelcast.internal.cluster.impl.operations
 
AbstractJoinOperation() - Constructor for class com.hazelcast.internal.cluster.impl.operations.AbstractJoinOperation
 
AbstractJsonGetter - Class in com.hazelcast.query.impl.getters
 
AbstractKeyBasedMultiMapOperation - Class in com.hazelcast.multimap.impl.operations
 
AbstractKeyBasedMultiMapOperation() - Constructor for class com.hazelcast.multimap.impl.operations.AbstractKeyBasedMultiMapOperation
 
AbstractKeyBasedMultiMapOperation(String, Data) - Constructor for class com.hazelcast.multimap.impl.operations.AbstractKeyBasedMultiMapOperation
 
AbstractKeyBasedMultiMapOperation(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.AbstractKeyBasedMultiMapOperation
 
AbstractLoadBalancer - Class in com.hazelcast.client.util
An abstract LoadBalancer implementation.
AbstractLoadBalancer() - Constructor for class com.hazelcast.client.util.AbstractLoadBalancer
 
AbstractLocalOperation - Class in com.hazelcast.spi.impl.operationservice
Abstract class for local operations, which should not be serializable.
AbstractLocalOperation() - Constructor for class com.hazelcast.spi.impl.operationservice.AbstractLocalOperation
 
AbstractLockOperation - Class in com.hazelcast.internal.locksupport.operations
 
AbstractLockOperation() - Constructor for class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
AbstractLockOperation(ObjectNamespace, Data, long) - Constructor for class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
AbstractLockOperation(ObjectNamespace, Data, long, long) - Constructor for class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
AbstractLockOperation(ObjectNamespace, Data, long, long, long) - Constructor for class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
AbstractLogger - Class in com.hazelcast.logging
Abstract ILogger implementation that provides implementations for convenience methods like finest, info, warning and severe.
AbstractLogger() - Constructor for class com.hazelcast.logging.AbstractLogger
 
AbstractLongRegisterOperation - Class in com.hazelcast.internal.longregister.operations
 
AbstractLongRegisterOperation() - Constructor for class com.hazelcast.internal.longregister.operations.AbstractLongRegisterOperation
 
AbstractLongRegisterOperation(String) - Constructor for class com.hazelcast.internal.longregister.operations.AbstractLongRegisterOperation
 
AbstractManagementOperation - Class in com.hazelcast.internal.management.operation
 
AbstractManagementOperation() - Constructor for class com.hazelcast.internal.management.operation.AbstractManagementOperation
 
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
 
AbstractMapDataStore<K,V> - Class in com.hazelcast.map.impl.mapstore
Abstract map data store contains common functionality of map data stores.
AbstractMapDataStore(MapStoreContext) - Constructor for class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
 
AbstractMapOperationFactory - Class in com.hazelcast.map.impl.operation
 
AbstractMapOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.AbstractMapOperationFactory
 
AbstractMapPartitionIterator<K,V> - Class in com.hazelcast.map.impl.iterator
Base class for iterating a partition.
AbstractMapPartitionIterator(IMap<K, V>, int, int, boolean) - Constructor for class com.hazelcast.map.impl.iterator.AbstractMapPartitionIterator
 
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
 
AbstractMapPutWithMaxIdleMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.map
 
AbstractMapPutWithMaxIdleMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.AbstractMapPutWithMaxIdleMessageTask
 
AbstractMapQueryMessageTask<P,QueryResult extends Result,AccumulatedResults,ReducedResult> - Class in com.hazelcast.client.impl.protocol.task.map
 
AbstractMapQueryMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
 
AbstractMapQueryPartitionIterator<K,V,R> - Class in com.hazelcast.map.impl.iterator
Base class for iterating a partition with a Predicate and a Projection.
AbstractMapQueryPartitionIterator(IMap<K, V>, int, int, Predicate<K, V>, Projection<? super Map.Entry<K, V>, R>) - Constructor for class com.hazelcast.map.impl.iterator.AbstractMapQueryPartitionIterator
 
AbstractMapSetMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.map
 
AbstractMapSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.AbstractMapSetMessageTask
 
AbstractMember - Class in com.hazelcast.cluster.impl
 
AbstractMember() - Constructor for class com.hazelcast.cluster.impl.AbstractMember
 
AbstractMember(Map<EndpointQualifier, Address>, MemberVersion, UUID, Map<String, String>, boolean) - Constructor for class com.hazelcast.cluster.impl.AbstractMember
 
AbstractMember(AbstractMember) - Constructor for class com.hazelcast.cluster.impl.AbstractMember
 
AbstractMergeRunnable<K,V,Store,MergingItem extends MergingEntry<K,V>> - Class in com.hazelcast.spi.impl.merge
Used by ICache, IMap and ReplicatedMap to provide a merge runnable for SplitBrainHandlerService.prepareMergeRunnable().
AbstractMergeRunnable(String, Collection<Store>, AbstractSplitBrainHandlerService<Store>, NodeEngine) - Constructor for class com.hazelcast.spi.impl.merge.AbstractMergeRunnable
 
AbstractMergingEntryImpl<K,V,T extends AbstractMergingEntryImpl<K,V,T>> - Class in com.hazelcast.spi.impl.merge
Implementation of MergingEntry.
AbstractMergingEntryImpl() - Constructor for class com.hazelcast.spi.impl.merge.AbstractMergingEntryImpl
 
AbstractMergingEntryImpl(SerializationService) - Constructor for class com.hazelcast.spi.impl.merge.AbstractMergingEntryImpl
 
AbstractMergingValueImpl<V,T extends AbstractMergingValueImpl<V,T>> - Class in com.hazelcast.spi.impl.merge
Implementation of MergingValue.
AbstractMergingValueImpl() - Constructor for class com.hazelcast.spi.impl.merge.AbstractMergingValueImpl
 
AbstractMergingValueImpl(SerializationService) - Constructor for class com.hazelcast.spi.impl.merge.AbstractMergingValueImpl
 
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
 
AbstractMultiMapOperation - Class in com.hazelcast.multimap.impl.operations
 
AbstractMultiMapOperation() - Constructor for class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
 
AbstractMultiMapOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
 
AbstractMultiPartitionMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
 
AbstractMultiPartitionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractMultiPartitionMessageTask
 
AbstractMultiTargetMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
 
AbstractMultiTargetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractMultiTargetMessageTask
 
AbstractMultiValueGetter - Class in com.hazelcast.query.impl.getters
 
AbstractMultiValueGetter(Getter, String, Class<?>, Class) - Constructor for class com.hazelcast.query.impl.getters.AbstractMultiValueGetter
 
AbstractNamedContainerCollector<C> - Class in com.hazelcast.spi.impl.merge
Base implementation of AbstractContainerCollector for data structures which reference their containers by name.
AbstractNamedContainerCollector(NodeEngine, ConcurrentMap<String, C>) - Constructor for class com.hazelcast.spi.impl.merge.AbstractNamedContainerCollector
 
AbstractNamedOperation - Class in com.hazelcast.spi.impl.operationservice
 
AbstractNamedOperation(String) - Constructor for class com.hazelcast.spi.impl.operationservice.AbstractNamedOperation
 
AbstractNamedOperation() - Constructor for class com.hazelcast.spi.impl.operationservice.AbstractNamedOperation
 
AbstractNamedSerializableOperation - Class in com.hazelcast.replicatedmap.impl.operation
 
AbstractNamedSerializableOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.AbstractNamedSerializableOperation
 
AbstractNearCacheRecord<V> - Class in com.hazelcast.internal.nearcache.impl.record
Abstract implementation of NearCacheRecord with value and expiration time as internal state.
AbstractNearCacheRecord(V, long, long) - Constructor for class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
AbstractNearCacheRecordStore<K,V,KS,R extends NearCacheRecord,NCRM extends SampleableNearCacheRecordMap<KS,R>> - Class in com.hazelcast.internal.nearcache.impl.store
Abstract implementation of NearCacheRecordStore and EvictionListener.
AbstractNearCacheRecordStore(NearCacheConfig, SerializationService, ClassLoader) - Constructor for class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
AbstractNearCacheRecordStore(NearCacheConfig, NearCacheStatsImpl, SerializationService, ClassLoader) - Constructor for class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
AbstractNearCacheRecordStore.ReserveForUpdateFunction - Class in com.hazelcast.internal.nearcache.impl.store
 
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
 
AbstractPartitionPrimaryReplicaAntiEntropyTask - Class in com.hazelcast.internal.partition.impl
 
AbstractPartitionPrimaryReplicaAntiEntropyTask(NodeEngineImpl, int) - Constructor for class com.hazelcast.internal.partition.impl.AbstractPartitionPrimaryReplicaAntiEntropyTask
 
AbstractPbeReplacer - Class in com.hazelcast.config.replacer
The common parent for ConfigReplacer implementations which allow to mask values by encrypting the value.
AbstractPbeReplacer() - Constructor for class com.hazelcast.config.replacer.AbstractPbeReplacer
 
AbstractPingAwareSplitBrainProtectionFunction - Class in com.hazelcast.splitbrainprotection.impl
Base class for split brain protection functions which may use ICMP failure detector information to conclude whether the minimum cluster size property is satisfied.
AbstractPingAwareSplitBrainProtectionFunction() - Constructor for class com.hazelcast.splitbrainprotection.impl.AbstractPingAwareSplitBrainProtectionFunction
 
AbstractPNCounterOperation - Class in com.hazelcast.internal.crdt.pncounter.operations
Base class for PNCounter query and mutation operation implementations.
AbstractPredicate<K,V> - Class in com.hazelcast.query.impl.predicates
Provides base features for predicates, such as extraction and conversion of the attribute's value.
AbstractPredicate() - Constructor for class com.hazelcast.query.impl.predicates.AbstractPredicate
 
AbstractPredicate(String) - Constructor for class com.hazelcast.query.impl.predicates.AbstractPredicate
 
AbstractProxySessionManager - Class in com.hazelcast.cp.internal.session
Implements session management APIs for Raft-based server and client proxies
AbstractProxySessionManager() - Constructor for class com.hazelcast.cp.internal.session.AbstractProxySessionManager
 
AbstractQueryCacheConfigurator - Class in com.hazelcast.map.impl.querycache.subscriber
Abstract QueryCacheConfigurator includes common functionality.
AbstractQueryCacheConfigurator(ClassLoader, QueryCacheEventService) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.AbstractQueryCacheConfigurator
 
AbstractQueryCacheEndToEndConstructor - Class in com.hazelcast.map.impl.querycache.subscriber
Provides generic functionality for QueryCacheEndToEndConstructor implementations.
AbstractQueryCacheEndToEndConstructor(QueryCacheRequest) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.AbstractQueryCacheEndToEndConstructor
 
AbstractRecord<V> - Class in com.hazelcast.map.impl.record
 
AbstractRemoveListenerMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
Base class for remove listener message tasks that removes a client listener registration from a node
AbstractRemoveListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractRemoveListenerMessageTask
 
AbstractReplicatedMapAddEntryListenerMessageTask<Parameter> - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
 
AbstractReplicatedMapAddEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
 
AbstractReplicatedMapOperation - Class in com.hazelcast.replicatedmap.impl.operation
 
AbstractReplicatedMapOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
 
AbstractReplicatedRecordStore<K,V> - Class in com.hazelcast.replicatedmap.impl.record
This is the base class for all ReplicatedRecordStore implementations
AbstractReplicatedRecordStore(String, ReplicatedMapService, int) - Constructor for class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
AbstractResponseHandlerTask - Class in com.hazelcast.cp.internal.raft.impl.handler
Base class for response handler tasks.
AbstractRingBufferOperation - Class in com.hazelcast.ringbuffer.impl.operations
Common logic for all ring buffer operations : getting the ring buffer container or creating a new one if necessary serialization/deserialization of ring buffer name defines the factory ID for the IdentifiedDataSerializable
AbstractRingBufferOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.AbstractRingBufferOperation
 
AbstractRingBufferOperation(String) - Constructor for class com.hazelcast.ringbuffer.impl.operations.AbstractRingBufferOperation
 
AbstractScheduledExecutorContainerHolder - Class in com.hazelcast.scheduledexecutor.impl
 
AbstractScheduledExecutorContainerHolder(NodeEngine) - Constructor for class com.hazelcast.scheduledexecutor.impl.AbstractScheduledExecutorContainerHolder
 
AbstractSchedulerOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
AbstractSerializableOperation - Class in com.hazelcast.replicatedmap.impl.operation
 
AbstractSerializableOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.AbstractSerializableOperation
 
AbstractSerializationService - Class in com.hazelcast.internal.serialization.impl
 
AbstractSerializationService.Builder<T extends AbstractSerializationService.Builder<T>> - Class in com.hazelcast.internal.serialization.impl
 
AbstractSplitBrainHandlerService<Store> - Class in com.hazelcast.spi.impl.merge
Collects mergeable stores and passes them to merge-runnable.
AbstractSplitBrainHandlerService(NodeEngine) - Constructor for class com.hazelcast.spi.impl.merge.AbstractSplitBrainHandlerService
 
AbstractSplitBrainMergePolicy<V,T extends MergingValue<V>> - Class in com.hazelcast.spi.impl.merge
Abstract implementation of SplitBrainMergePolicy for the out-of-the-box merge policies.
AbstractSplitBrainMergePolicy() - Constructor for class com.hazelcast.spi.impl.merge.AbstractSplitBrainMergePolicy
 
AbstractSubscriberContext - Class in com.hazelcast.map.impl.querycache.subscriber
Abstract implementation of SubscriberContext.
AbstractSubscriberContext(QueryCacheContext) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.AbstractSubscriberContext
 
AbstractSymmetricEncryptionConfig<T extends AbstractSymmetricEncryptionConfig> - Class in com.hazelcast.config
Base class for symmetric encryption configuration classes.
AbstractSymmetricEncryptionConfig() - Constructor for class com.hazelcast.config.AbstractSymmetricEncryptionConfig
 
AbstractTextCommand - Class in com.hazelcast.internal.ascii
 
AbstractTextCommand(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.internal.ascii.AbstractTextCommand
 
AbstractTextCommandProcessor<T> - Class in com.hazelcast.internal.ascii
 
AbstractTextCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.AbstractTextCommandProcessor
 
AbstractTransactionalCollectionProxy<S extends RemoteService,E> - Class in com.hazelcast.collection.impl.txncollection
 
AbstractTransactionalCollectionProxy(String, Transaction, NodeEngine, S) - Constructor for class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
 
AbstractTransactionalMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
 
AbstractTransactionalMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractTransactionalMessageTask
 
AbstractTxOperation - Class in com.hazelcast.transaction.impl.operations
 
AbstractTxOperation() - Constructor for class com.hazelcast.transaction.impl.operations.AbstractTxOperation
 
AbstractUnsafeRaftOp - Class in com.hazelcast.cp.internal.operation.unsafe
Base class for Raft operations to be executed in UNSAFE mode.
AbstractVisitor - Class in com.hazelcast.query.impl.predicates
Base class for all visitors.
AbstractVisitor() - Constructor for class com.hazelcast.query.impl.predicates.AbstractVisitor
 
AbstractWaitNotifyKey - Class in com.hazelcast.spi.impl.operationservice
Abstract implementation of the WaitNotifyKey.
AbstractWaitNotifyKey(String, String) - Constructor for class com.hazelcast.spi.impl.operationservice.AbstractWaitNotifyKey
 
AbstractWanAntiEntropyEventBase - Class in com.hazelcast.internal.management.events
 
AbstractWanAntiEntropyEventBase(UUID, String, String, String) - Constructor for class com.hazelcast.internal.management.events.AbstractWanAntiEntropyEventBase
 
AbstractWanPublisherConfig - Class in com.hazelcast.config
Base class for WAN publisher configuration.
AbstractWanPublisherConfig() - Constructor for class com.hazelcast.config.AbstractWanPublisherConfig
 
AbstractXAOperation - Class in com.hazelcast.transaction.impl.xa.operations
 
AbstractXAOperation() - Constructor for class com.hazelcast.transaction.impl.xa.operations.AbstractXAOperation
 
AbstractXmlConfigBuilder - Class in com.hazelcast.config
Contains logic for replacing system variables in the XML file and importing XML files from different locations.
AbstractXmlConfigBuilder() - Constructor for class com.hazelcast.config.AbstractXmlConfigBuilder
 
AbstractXmlConfigBuilder.ConfigType - Enum in com.hazelcast.config
 
AbstractXmlConfigHelper - Class in com.hazelcast.config
Contains Hazelcast XML Configuration helper methods and variables.
AbstractXmlConfigHelper() - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper
 
AbstractYamlConfigBuilder - Class in com.hazelcast.config
Contains logic for replacing system variables in the YAML file and importing YAML files from different locations.
AbstractYamlConfigBuilder() - Constructor for class com.hazelcast.config.AbstractYamlConfigBuilder
 
AbstractYamlNode - Class in com.hazelcast.internal.yaml
 
accept(ClientMessage) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
accept(ClientMessage) - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
accept(Object, Throwable) - Method in class com.hazelcast.client.impl.protocol.task.AbstractAddressMessageTask
 
accept(Map<Integer, Object>, Throwable) - Method in class com.hazelcast.client.impl.protocol.task.AbstractAllPartitionsMessageTask
 
accept(Object, Throwable) - Method in class com.hazelcast.client.impl.protocol.task.AbstractInvocationMessageTask
 
accept(Map<Integer, Object>, Throwable) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMultiPartitionMessageTask
 
accept(Object, Throwable) - Method in class com.hazelcast.client.impl.protocol.task.AbstractPartitionMessageTask
 
accept(Long) - Method in class com.hazelcast.client.impl.protocol.task.AddBackupListenerMessageTask
 
accept(Object, Throwable) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheCreateConfigMessageTask
 
accept(Object, Throwable) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AbstractAddConfigMessageTask
 
accept(Object, Throwable) - Method in class com.hazelcast.cp.internal.client.AbstractCPMessageTask
 
accept(Object, Throwable) - Method in class com.hazelcast.cp.internal.operation.RaftQueryOp
 
accept(Object, Throwable) - Method in class com.hazelcast.cp.internal.operation.RaftReplicateOp
 
accept(Object, Throwable) - Method in class com.hazelcast.cp.internal.operation.TransferLeadershipOp
 
accept(T, Throwable) - Method in class com.hazelcast.executor.impl.ExecutionCallbackAdapter
 
accept(Packet) - Method in class com.hazelcast.internal.nio.tcp.ClientViewUnifiedEndpointManager
 
accept(Packet) - Method in class com.hazelcast.internal.nio.tcp.MemberViewUnifiedEndpointManager
 
accept(Packet) - Method in class com.hazelcast.internal.nio.tcp.TcpIpEndpointManager
 
accept(Packet) - Method in class com.hazelcast.internal.nio.tcp.TextViewUnifiedEndpointManager
 
accept(String) - Method in class com.hazelcast.internal.usercodedeployment.impl.filter.ClassBlacklistFilter
 
accept(String) - Method in class com.hazelcast.internal.usercodedeployment.impl.filter.ClassWhitelistFilter
 
accept(Member) - Method in class com.hazelcast.internal.usercodedeployment.impl.filter.MemberAttributeFilter
 
accept(int, int, V) - Method in interface com.hazelcast.internal.util.collection.BiInt2ObjectMap.EntryConsumer
A map entry
accept(T) - Method in class com.hazelcast.internal.util.filter.AlwaysApplyFilter
 
accept(T) - Method in class com.hazelcast.internal.util.filter.AndFilter
 
accept(T) - Method in interface com.hazelcast.internal.util.filter.Filter
Return {true} when object matches a condition
accept(T, U) - Method in interface com.hazelcast.internal.util.function.BiConsumerEx
 
accept(T) - Method in interface com.hazelcast.internal.util.function.ConsumerEx
 
accept(long, long) - Method in interface com.hazelcast.internal.util.function.LongLongConsumer
Accept a key and value that comes as a tuple of longs.
accept(Visitor, Indexes) - Method in class com.hazelcast.query.impl.predicates.AndPredicate
 
accept(Visitor, Indexes) - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
 
accept(Visitor, Indexes) - Method in class com.hazelcast.query.impl.predicates.NotPredicate
 
accept(Visitor, Indexes) - Method in class com.hazelcast.query.impl.predicates.OrPredicate
 
accept(Visitor, Indexes) - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
 
accept(Visitor, Indexes) - Method in class com.hazelcast.query.impl.predicates.SqlPredicate
 
accept(Visitor, Indexes) - Method in interface com.hazelcast.query.impl.predicates.VisitablePredicate
Accept visitor.
accept(T, Throwable) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture.AbstractEitherNode
 
accept(Packet) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
Handles an asynchronous remote event with a RemoteEventProcessor.
accept(Packet) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
accept(Packet) - Method in class com.hazelcast.spi.impl.operationservice.impl.InboundResponseHandler
 
accept(Packet) - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationMonitor
 
accept(Packet) - Method in class com.hazelcast.spi.impl.PacketDispatcher
 
accept(ReadResultSet<ReliableTopicMessage>, Throwable) - Method in class com.hazelcast.topic.impl.reliable.MessageRunner
 
acceptEither(CompletionStage<? extends V>, Consumer<? super V>) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
acceptEither(CompletionStage<? extends V>, Consumer<? super V>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
acceptEither(CompletionStage<? extends V>, Consumer<? super V>) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
acceptEither(CompletionStage<? extends V>, Consumer<? super V>) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
acceptEitherAsync(CompletionStage<? extends V>, Consumer<? super V>) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
acceptEitherAsync(CompletionStage<? extends V>, Consumer<? super V>, Executor) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
acceptEitherAsync(CompletionStage<? extends ClientMessage>, Consumer<? super ClientMessage>, Executor) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
acceptEitherAsync(CompletionStage<? extends V>, Consumer<? super V>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
acceptEitherAsync(CompletionStage<? extends V>, Consumer<? super V>, Executor) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
acceptEitherAsync(CompletionStage<? extends V>, Consumer<? super V>) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
acceptEitherAsync(CompletionStage<? extends V>, Consumer<? super V>, Executor) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
acceptEitherAsync(CompletionStage<? extends V>, Consumer<? super V>) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
acceptEitherAsync(CompletionStage<? extends V>, Consumer<? super V>, Executor) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
acceptEx(T, U) - Method in interface com.hazelcast.internal.util.function.BiConsumerEx
Exception-declaring version of BiConsumer.accept(T, U).
acceptEx(T) - Method in interface com.hazelcast.internal.util.function.ConsumerEx
Exception-declaring version of Consumer.accept(T)
acceptVisitor(Predicate[], Visitor, Indexes) - Static method in class com.hazelcast.query.impl.predicates.VisitorUtils
Accept visitor by all predicates.
access() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
ACCESS_CONTROL - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
accessHit - Variable in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
accessHit - Variable in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
accessRecord(Data, R, ExpiryPolicy, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
accessRecord(Record, long) - Method in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
accessRecord(Record, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Callback which is called when the record is being accessed from the record or index store.
accessTime - Variable in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
accessTime - Variable in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
accumulate(I) - Method in class com.hazelcast.aggregation.Aggregator
Accumulates the given entries.
accumulate(I) - Method in class com.hazelcast.aggregation.impl.AbstractAggregator
 
accumulate(E) - Method in interface com.hazelcast.map.impl.querycache.accumulator.Accumulator
Adds event to this accumulator.
accumulate(E) - Method in class com.hazelcast.map.impl.querycache.accumulator.BasicAccumulator
 
accumulate(QueryCacheEventData) - Method in class com.hazelcast.map.impl.querycache.subscriber.SubscriberAccumulator
 
accumulateExtracted(I, E) - Method in class com.hazelcast.aggregation.impl.AbstractAggregator
Accumulates a single extracted value.
accumulateExtracted(I, BigDecimal) - Method in class com.hazelcast.aggregation.impl.BigDecimalAverageAggregator
 
accumulateExtracted(I, BigDecimal) - Method in class com.hazelcast.aggregation.impl.BigDecimalSumAggregator
 
accumulateExtracted(I, BigInteger) - Method in class com.hazelcast.aggregation.impl.BigIntegerAverageAggregator
 
accumulateExtracted(I, BigInteger) - Method in class com.hazelcast.aggregation.impl.BigIntegerSumAggregator
 
accumulateExtracted(I, Object) - Method in class com.hazelcast.aggregation.impl.CountAggregator
 
accumulateExtracted(I, R) - Method in class com.hazelcast.aggregation.impl.DistinctValuesAggregator
 
accumulateExtracted(I, Number) - Method in class com.hazelcast.aggregation.impl.DoubleAverageAggregator
 
accumulateExtracted(I, Number) - Method in class com.hazelcast.aggregation.impl.DoubleSumAggregator
 
accumulateExtracted(I, Number) - Method in class com.hazelcast.aggregation.impl.FixedSumAggregator
 
accumulateExtracted(I, Number) - Method in class com.hazelcast.aggregation.impl.FloatingPointSumAggregator
 
accumulateExtracted(I, Number) - Method in class com.hazelcast.aggregation.impl.IntegerAverageAggregator
 
accumulateExtracted(I, Number) - Method in class com.hazelcast.aggregation.impl.IntegerSumAggregator
 
accumulateExtracted(I, Number) - Method in class com.hazelcast.aggregation.impl.LongAverageAggregator
 
accumulateExtracted(I, Number) - Method in class com.hazelcast.aggregation.impl.LongSumAggregator
 
accumulateExtracted(I, R) - Method in class com.hazelcast.aggregation.impl.MaxAggregator
 
accumulateExtracted(I, Comparable) - Method in class com.hazelcast.aggregation.impl.MaxByAggregator
 
accumulateExtracted(I, R) - Method in class com.hazelcast.aggregation.impl.MinAggregator
 
accumulateExtracted(I, Comparable) - Method in class com.hazelcast.aggregation.impl.MinByAggregator
 
accumulateExtracted(I, Number) - Method in class com.hazelcast.aggregation.impl.NumberAverageAggregator
 
accumulateOrSendExpiredKeysToBackup(Data, R) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
accumulateParallel(Aggregator, Collection<QueryableEntry>) - Method in class com.hazelcast.map.impl.query.ParallelAccumulationExecutor
 
AccumulationExecutor - Interface in com.hazelcast.map.impl.query
Executes the accumulation phase of the Aggregator.
Accumulator<E extends Sequenced> - Interface in com.hazelcast.map.impl.querycache.accumulator
Accumulator for events which have a sequence number.
ACCUMULATOR_CONSUMER - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
AccumulatorFactory - Interface in com.hazelcast.map.impl.querycache.accumulator
Factory which is used to create an Accumulator.
AccumulatorHandler<T> - Interface in com.hazelcast.map.impl.querycache.accumulator
Used to handle elements of an Accumulator.
AccumulatorInfo - Class in com.hazelcast.map.impl.querycache.accumulator
Metadata for an Accumulator.
AccumulatorInfo() - Constructor for class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
 
accumulatorInfoCountOfMap(String) - Method in class com.hazelcast.map.impl.querycache.accumulator.DefaultAccumulatorInfoSupplier
 
AccumulatorInfoSupplier - Interface in com.hazelcast.map.impl.querycache.accumulator
Supplies AccumulatorInfo according to name of IMap and name of QueryCache.
AccumulatorProcessor<T> - Interface in com.hazelcast.map.impl.querycache.accumulator
Responsible for processing of an event of an Accumulator.
AccumulatorScannerTask - Class in com.hazelcast.map.impl.querycache.accumulator
Task for scanning all Accumulator instances of all QueryCaches on this node.
AccumulatorScannerTask(QueryCacheContext) - Constructor for class com.hazelcast.map.impl.querycache.accumulator.AccumulatorScannerTask
 
AccumulatorSweeper - Class in com.hazelcast.map.impl.querycache.publisher
Responsible for sweeping all registered accumulators of a PublisherContext.
acquire() - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionAwareSemaphoreProxy
 
acquire(int) - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionAwareSemaphoreProxy
 
acquire() - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionlessSemaphoreProxy
 
acquire(int) - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionlessSemaphoreProxy
 
acquire(CPGroupId, String, LockInvocationKey, long) - Method in class com.hazelcast.cp.internal.datastructures.lock.LockService
 
acquire() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionAwareSemaphoreProxy
 
acquire(int) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionAwareSemaphoreProxy
 
acquire() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionlessSemaphoreProxy
 
acquire(int) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionlessSemaphoreProxy
 
acquire() - Method in interface com.hazelcast.cp.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.cp.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_INVOCATION_KEY - Static variable in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreDataSerializerHook
 
ACQUIRE_PERMITS_OP - Static variable in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreDataSerializerHook
 
AcquireInvocationKey - Class in com.hazelcast.cp.internal.datastructures.semaphore
Represents acquire() invocation of a semaphore endpoint.
AcquireInvocationKey(long, UUID, Address, long, SemaphoreEndpoint, int) - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.AcquireInvocationKey
 
acquirePermits(CPGroupId, String, AcquireInvocationKey, long) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreService
 
AcquirePermitsMessageTask - Class in com.hazelcast.cp.internal.datastructures.semaphore.client
Client message task for AcquirePermitsOp
AcquirePermitsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.client.AcquirePermitsMessageTask
 
AcquirePermitsOp - Class in com.hazelcast.cp.internal.datastructures.semaphore.operation
Operation for ISemaphore.acquire()
AcquirePermitsOp() - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.operation.AcquirePermitsOp
 
AcquirePermitsOp(String, long, long, UUID, int, long) - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.operation.AcquirePermitsOp
 
acquirePromotionPermit() - Method in class com.hazelcast.internal.partition.impl.MigrationManager
Acquires promotion commit permit which is needed while running promotion commit to prevent concurrent commits.
AcquireResult - Class in com.hazelcast.cp.internal.datastructures.lock
Represents result of a lock() request
AcquireResult - Class in com.hazelcast.cp.internal.datastructures.semaphore
Represents result of an ISemaphore.acquire() request
AcquireResult.AcquireStatus - Enum in com.hazelcast.cp.internal.datastructures.lock
 
AcquireResult.AcquireStatus - Enum in com.hazelcast.cp.internal.datastructures.semaphore
 
acquireSession(RaftGroupId) - Method in class com.hazelcast.cp.internal.session.AbstractProxySessionManager
Increments acquire count of the session.
acquireSession(RaftGroupId, int) - Method in class com.hazelcast.cp.internal.session.AbstractProxySessionManager
Increments acquire count of the session.
acquireSession() - Method in class com.hazelcast.cp.internal.session.SessionAwareProxy
Increments acquire count of the session.
acquireSession(int) - Method in class com.hazelcast.cp.internal.session.SessionAwareProxy
Increments acquire count of the session.
acquiresResource() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
ACTION_ACQUIRE - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_ADD - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_AGGREGATE - 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_PROJECTION - 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
 
ACTION_USER_CODE_DEPLOY - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ActionConstants - Class in com.hazelcast.security.permission
 
actions - Variable in class com.hazelcast.security.permission.InstancePermission
 
activate() - Method in interface com.hazelcast.osgi.impl.HazelcastInternalOSGiService
Activates the service.
Activator - Class in com.hazelcast.osgi.impl
Hazelcast OSGi bundle activator.
Activator() - Constructor for class com.hazelcast.osgi.impl.Activator
 
activeConnectionCount - Variable in class com.hazelcast.internal.management.dto.ConnectionManagerDTO
 
adaptListenerConfigs(List<ListenerConfigHolder>) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AbstractAddConfigMessageTask
 
add(E) - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
add(Object) - Method in interface com.hazelcast.cardinality.CardinalityEstimator
Add a new object in the estimation set.
add(long) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
 
ADD - Static variable in class com.hazelcast.cardinality.impl.CardinalityEstimatorDataSerializerHook
 
add(Object) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorProxy
 
add(long) - Method in interface com.hazelcast.cardinality.impl.hyperloglog.HyperLogLog
Aggregates the hash in the HyperLogLog registers.
add(long) - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.DenseHyperLogLogEncoder
 
add(long) - Method in interface com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogEncoder
Aggregates the hash value in the HyperLogLog registers, and returns a hint if the operation might have affected the cardinality, it is just a hint, and it relies to the respective implementation.
add(long) - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogImpl
 
add(long) - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.SparseHyperLogLogEncoder
 
add(ClientMessage.Frame) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
add(Object) - Method in class com.hazelcast.client.impl.proxy.ClientCardinalityEstimatorProxy
 
add(int, E) - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
add(E) - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
add(E) - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
add(E) - Method in class com.hazelcast.client.impl.proxy.ClientRingbufferProxy
 
add(E) - Method in class com.hazelcast.client.impl.proxy.ClientSetProxy
 
add(E) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnListProxy
 
add(E) - Method in class com.hazelcast.client.impl.proxy.txn.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(CompletionStage<E>) - Method in class com.hazelcast.core.Pipelining
Adds a future to this Pipelining or blocks until there is capacity to add the future to the Pipelining.
add(RaftEndpoint, long) - Method in class com.hazelcast.cp.internal.raft.impl.state.LeaderState
Add a new follower with the leader's lastLogIndex.
add(Callable) - Method in class com.hazelcast.durableexecutor.impl.TaskRingBuffer
Adds the task to next available spot and returns the sequence corresponding to that spot.
add(M) - Method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
 
add(int) - Method in class com.hazelcast.internal.json.JsonArray
Appends the JSON representation of the specified int value to the end of this array.
add(long) - Method in class com.hazelcast.internal.json.JsonArray
Appends the JSON representation of the specified long value to the end of this array.
add(float) - Method in class com.hazelcast.internal.json.JsonArray
Appends the JSON representation of the specified float value to the end of this array.
add(double) - Method in class com.hazelcast.internal.json.JsonArray
Appends the JSON representation of the specified double value to the end of this array.
add(boolean) - Method in class com.hazelcast.internal.json.JsonArray
Appends the JSON representation of the specified boolean value to the end of this array.
add(String) - Method in class com.hazelcast.internal.json.JsonArray
Appends the JSON representation of the specified string to the end of this array.
add(JsonValue) - Method in class com.hazelcast.internal.json.JsonArray
Appends the specified JSON value to the end of this array.
add(String, int) - Method in class com.hazelcast.internal.json.JsonObject
Appends a new member to the end of this object, with the specified name and the JSON representation of the specified int value.
add(String, long) - Method in class com.hazelcast.internal.json.JsonObject
Appends a new member to the end of this object, with the specified name and the JSON representation of the specified long value.
add(String, float) - Method in class com.hazelcast.internal.json.JsonObject
Appends a new member to the end of this object, with the specified name and the JSON representation of the specified float value.
add(String, double) - Method in class com.hazelcast.internal.json.JsonObject
Appends a new member to the end of this object, with the specified name and the JSON representation of the specified double value.
add(String, boolean) - Method in class com.hazelcast.internal.json.JsonObject
Appends a new member to the end of this object, with the specified name and the JSON representation of the specified boolean value.
add(String, String) - Method in class com.hazelcast.internal.json.JsonObject
Appends a new member to the end of this object, with the specified name and the JSON representation of the specified string.
add(String, JsonValue) - Method in class com.hazelcast.internal.json.JsonObject
Appends a new member to the end of this object, with the specified name and the specified JSON value.
add(E) - Method in class com.hazelcast.internal.metrics.managementcenter.ConcurrentArrayRingbuffer
Appends an item to the ring buffer.
add(T) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationQueue
 
add(T) - Method in class com.hazelcast.internal.util.collection.ImmutableInflatableSet
 
add(T) - Method in class com.hazelcast.internal.util.collection.ImmutableInflatableSet.ImmutableSetBuilder
 
add(Integer) - Method in class com.hazelcast.internal.util.collection.ImmutablePartitionIdSet
 
add(int) - Method in class com.hazelcast.internal.util.collection.ImmutablePartitionIdSet
 
add(T) - Method in class com.hazelcast.internal.util.collection.InflatableSet
 
add(T) - Method in class com.hazelcast.internal.util.collection.InflatableSet.Builder
 
add(Integer) - Method in class com.hazelcast.internal.util.collection.IntHashSet
 
add(int) - Method in class com.hazelcast.internal.util.collection.IntHashSet
Primitive specialised overload of {this#add(Integer)}
add(Long) - Method in class com.hazelcast.internal.util.collection.LongHashSet
add(long) - Method in class com.hazelcast.internal.util.collection.LongHashSet
Primitive specialised overload of {this#add(Long)}
add(long) - Method in interface com.hazelcast.internal.util.collection.LongSet
 
add(long) - Method in class com.hazelcast.internal.util.collection.LongSetHsa
 
add(E) - Method in class com.hazelcast.internal.util.collection.OAHashSet
 
add(E, int) - Method in class com.hazelcast.internal.util.collection.OAHashSet
Adds the specified element to this set if it is not already present.
add(Integer) - Method in class com.hazelcast.internal.util.collection.PartitionIdSet
 
add(int) - Method in class com.hazelcast.internal.util.collection.PartitionIdSet
 
add(T, long) - Method in class com.hazelcast.internal.util.ItemCounter
Add delta to the item
add(E) - Method in class com.hazelcast.internal.util.UnmodifiableListIterator
 
add(int) - Method in class com.hazelcast.json.internal.JsonPattern
 
add(JsonPattern) - Method in class com.hazelcast.json.internal.JsonPattern
 
add(Data, Data) - Method in class com.hazelcast.map.impl.MapEntries
 
add(K, V, long, long, UUID) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
 
add(long) - Method in class com.hazelcast.map.impl.mapstore.writebehind.NodeWideUsedCapacityCounter
Increments/decrements current value of node-wide-used-capacity counter by adding supplied delta.
add(Data, Object, long, long, UUID) - 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, long, UUID) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
add(QueryableEntry) - Method in class com.hazelcast.map.impl.query.AggregationResult
 
add(QueryableEntry) - Method in class com.hazelcast.map.impl.query.QueryResult
Adds the given entry to this result.
add(QueryableEntry) - Method in interface com.hazelcast.map.impl.query.Result
Adds the given entry to this result.
add(E) - Method in interface com.hazelcast.map.impl.querycache.accumulator.CyclicBuffer
Adds an event to this buffer and sets tail to the sequence of given event.
add(E) - Method in class com.hazelcast.map.impl.querycache.accumulator.DefaultCyclicBuffer
 
add(QueryCacheEventData) - Method in class com.hazelcast.map.impl.querycache.event.BatchEventData
 
add(Data, Data) - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordStore
 
add(QueryableEntry) - Method in class com.hazelcast.query.impl.FastMultiResultSet
 
add(T) - Method in class com.hazelcast.query.impl.getters.ImmutableMultiResult
 
add(T) - Method in class com.hazelcast.query.impl.getters.MultiResult
 
add(Data, Data) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
 
add(E) - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
 
add(Object) - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
 
add(E) - Method in interface com.hazelcast.ringbuffer.impl.Ringbuffer
Adds an item to the tail of the ringbuffer.
add(T) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
Adds one item to the ring buffer.
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, boolean) - Method in interface com.hazelcast.spi.impl.operationexecutor.impl.OperationQueue
Adds an task to this queue.
add(Object, boolean) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationQueueImpl
 
add(Address, long) - Method in class com.hazelcast.spi.impl.operationservice.CallsPerMember
 
add(Address, long) - Method in interface com.hazelcast.spi.impl.operationservice.LiveOperations
Registers an invocation with this object.
add(E) - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
 
add(Object) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Adds an item to the tail of the ringbuffer.
add(TransactionLogRecord) - Method in class com.hazelcast.transaction.impl.SuspendedTransaction
 
add(TransactionLogRecord) - Method in interface com.hazelcast.transaction.impl.Transaction
 
add(TransactionLogRecord) - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
add(TransactionLogRecord) - Method in class com.hazelcast.transaction.impl.TransactionLog
 
add(TransactionLogRecord) - Method in class com.hazelcast.transaction.impl.xa.XATransaction
 
add(E) - Method in interface com.hazelcast.transaction.TransactionalList
Adds a new item to the transactional list.
add(E) - Method in interface com.hazelcast.transaction.TransactionalSet
Add new item to transactional set.
ADD_ALL - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
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.internal.longregister.LongRegisterDataSerializerHook
 
ADD_AND_GET_OP - Static variable in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongDataSerializerHook
 
ADD_BACKUP - Static variable in class com.hazelcast.internal.longregister.LongRegisterDataSerializerHook
 
ADD_BACKUP_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
 
ADD_CACHE_CONFIG_OPERATION - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
ADD_CP_MEMBER_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
ADD_DYNAMIC_CONFIG_OP - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
ADD_INDEX - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
ADD_INDEX_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
ADD_INDEX_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
ADD_INTERCEPTOR - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
ADD_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
 
addAction(String) - Method in class com.hazelcast.config.PermissionConfig
 
addAddress(String...) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Adds given addresses to candidate address list that client will use to establish initial connection
addAll(Collection<? extends E>) - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
addAll(long[]) - Method in interface com.hazelcast.cardinality.impl.hyperloglog.HyperLogLog
Batch aggregation of hash values in the HyperLogLog registers.
addAll(long[]) - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogImpl
 
addAll(Addresses) - Method in class com.hazelcast.client.impl.connection.Addresses
 
addAll(int, Collection<? extends E>) - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
addAll(Collection<? extends E>) - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
addAll(Collection<? extends E>) - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
addAll(Collection<? extends E>) - Method in class com.hazelcast.client.impl.proxy.ClientSetProxy
 
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
Adds all items from the dataList to the queue.
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<? extends M>) - Method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
 
addAll(Collection<? extends T>) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationQueue
 
addAll(Collection<? extends T>) - Method in class com.hazelcast.internal.util.collection.ImmutableInflatableSet
 
addAll(PartitionIdSet) - Method in class com.hazelcast.internal.util.collection.ImmutablePartitionIdSet
 
addAll(Collection<? extends Integer>) - Method in class com.hazelcast.internal.util.collection.IntHashSet
 
addAll(Collection<? extends Long>) - Method in class com.hazelcast.internal.util.collection.LongHashSet
addAll(PartitionIdSet) - Method in class com.hazelcast.internal.util.collection.PartitionIdSet
 
addAll(Collection) - Method in class com.hazelcast.internal.util.ResultSet
 
addAll(Collection<? extends E>) - Method in class com.hazelcast.map.impl.query.QueryResultCollection
 
addAll(T[]) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
Adds all items to the ringbuffer.
addAll(Collection<? extends E>) - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
 
addAllAsync(Collection<? extends E>, OverflowPolicy) - Method in class com.hazelcast.client.impl.proxy.ClientRingbufferProxy
 
addAllAsync(Collection<? extends E>, OverflowPolicy) - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
 
addAllAsync(Collection<? extends E>, OverflowPolicy) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Adds all the items of a collection to the tail of the Ringbuffer.
addAllBackup(Map<Long, Data>) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
addAllBackup(Map<Long, Data>) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Offers the items to the backup map in bulk.
AddAllBackupOperation - Class in com.hazelcast.collection.impl.queue.operations
Provides backup functionality for AddAllOperation
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
Backup operation for ring buffer AddAllOperation.
AddAllBackupOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddAllBackupOperation
 
AddAllBackupOperation(String, long, 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
Adds a batch of items to the ring buffer.
AddAllOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
 
AddAllOperation(String, Data[], OverflowPolicy) - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
 
addAllRows(Collection<QueryResultRow>) - Method in class com.hazelcast.map.impl.query.QueryResultCollection
 
addAndGet(long) - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
addAndGet(long) - Method in class com.hazelcast.client.impl.proxy.ClientPNCounterProxy
 
addAndGet(long) - Method in interface com.hazelcast.cp.IAtomicLong
Atomically adds the given value to the current value.
addAndGet(long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLong
 
addAndGet(long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
addAndGet(long) - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Adds the given value to the current value.
addAndGet(long, VectorClock) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterImpl
Adds the given value to the current value.
addAndGet(long) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterProxy
 
addAndGet(long) - Method in class com.hazelcast.internal.jmx.AtomicLongMBean
 
addAndGet(long) - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
addAndGet(long) - Method in class com.hazelcast.internal.longregister.LongRegister
 
addAndGet(long) - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
addAndGetAsync(long) - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
addAndGetAsync(long) - Method in interface com.hazelcast.cp.IAtomicLong
Atomically adds the given value to the current value.
addAndGetAsync(long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
addAndGetAsync(long) - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
addAndGetAsync(long) - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
AddAndGetMessageTask - Class in com.hazelcast.cp.internal.datastructures.atomiclong.client
Client message task for AddAndGetOp
AddAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.client.AddAndGetMessageTask
 
addAndGetMissedSequenceCount(long) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataContainer
 
AddAndGetOp - Class in com.hazelcast.cp.internal.datastructures.atomiclong.operation
AddAndGetOp() - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.operation.AddAndGetOp
 
AddAndGetOp(String, long) - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.operation.AddAndGetOp
 
AddAndGetOperation - Class in com.hazelcast.internal.longregister.operations
 
AddAndGetOperation() - Constructor for class com.hazelcast.internal.longregister.operations.AddAndGetOperation
 
AddAndGetOperation(String, long) - Constructor for class com.hazelcast.internal.longregister.operations.AddAndGetOperation
 
addAny() - Method in class com.hazelcast.json.internal.JsonPattern
Marks this pattern as having "any" keyword.
addAsync(Object) - Method in interface com.hazelcast.cardinality.CardinalityEstimator
Add a new object in the estimation set.
addAsync(Object) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorProxy
 
addAsync(Object) - Method in class com.hazelcast.client.impl.proxy.ClientCardinalityEstimatorProxy
 
addAsync(E, OverflowPolicy) - Method in class com.hazelcast.client.impl.proxy.ClientRingbufferProxy
 
addAsync(E, OverflowPolicy) - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
 
addAsync(E, OverflowPolicy) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Asynchronously writes an item with a configurable OverflowPolicy.
addAttribute(String) - Method in class com.hazelcast.config.IndexConfig
Adds an index attribute with the given.
addAttribute(String) - Method in class com.hazelcast.internal.config.IndexConfigReadOnly
 
addAttributeConfig(AttributeConfig) - Method in class com.hazelcast.config.MapConfig
 
addAttributeInternal(String) - Method in class com.hazelcast.config.IndexConfig
 
addBackup(long, Data) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
addBackup(K, V, long, long, UUID) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
 
addBackup(Data, Object, long, long, UUID) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
Throw no exception while putting backup entry.
addBackup(Data, Object, long, long, UUID) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
addBackupListener(UUID, Consumer<Long>) - Method in interface com.hazelcast.client.impl.ClientEngine
 
addBackupListener(UUID, Consumer<Long>) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
addBackupListener(UUID, Consumer<Long>) - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
addBackupListener() - Method in class com.hazelcast.client.impl.spi.impl.SmartClientInvocationService
 
AddBackupListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task
 
AddBackupListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AddBackupListenerMessageTask
 
AddBackupOperation - Class in com.hazelcast.internal.longregister.operations
 
AddBackupOperation() - Constructor for class com.hazelcast.internal.longregister.operations.AddBackupOperation
 
AddBackupOperation(String, long) - Constructor for class com.hazelcast.internal.longregister.operations.AddBackupOperation
 
AddBackupOperation - Class in com.hazelcast.ringbuffer.impl.operations
Backup operation for ring buffer AddOperation.
AddBackupOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddBackupOperation
 
AddBackupOperation(String, long, Data) - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddBackupOperation
 
addBooleanArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addBooleanField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addByteArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addByteField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addCacheConfig(CacheConfig) - Method in class com.hazelcast.cache.impl.operation.OnJoinCacheOperation
 
addCacheConfig(CacheSimpleConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
addCacheConfig(CacheSimpleConfig) - Method in class com.hazelcast.config.Config
Adds the cache configuration.
addCacheConfig(CacheSimpleConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
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
 
AddCacheConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
AddCacheConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddCacheConfigMessageTask
 
AddCacheConfigOperation - Class in com.hazelcast.cache.impl.operation
 
AddCacheConfigOperation() - Constructor for class com.hazelcast.cache.impl.operation.AddCacheConfigOperation
 
AddCacheConfigOperation(PreJoinCacheConfig) - Constructor for class com.hazelcast.cache.impl.operation.AddCacheConfigOperation
 
AddCacheConfigOperationSupplier - Class in com.hazelcast.cache.impl.operation
 
AddCacheConfigOperationSupplier(PreJoinCacheConfig) - Constructor for class com.hazelcast.cache.impl.operation.AddCacheConfigOperationSupplier
 
addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.config.AbstractCacheConfig
Add a configuration for a CacheEntryListener.
addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in interface com.hazelcast.config.CacheConfiguration
Add a configuration for a CacheEntryListener.
addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
addCachePartitionLostListenerConfig(CachePartitionLostListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
Adds the CachePartitionLostListenerConfig to partitionLostListenerConfigs.
addCachePartitionLostListenerConfig(CachePartitionLostListenerConfig) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
addCacheResource(String, Closeable) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
addCardinalityEstimator(String, CardinalityEstimatorContainer) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorService
 
addCardinalityEstimatorConfig(CardinalityEstimatorConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
addCardinalityEstimatorConfig(CardinalityEstimatorConfig) - Method in class com.hazelcast.config.Config
Adds the cardinality estimator configuration.
addCardinalityEstimatorConfig(CardinalityEstimatorConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
AddCardinalityEstimatorConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
AddCardinalityEstimatorConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddCardinalityEstimatorConfigMessageTask
 
addCharArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addCharField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addChild(String, YamlNode) - Method in interface com.hazelcast.internal.yaml.MutableYamlMapping
Adds a new child node to the mapping with the provided name
addChild(YamlNode) - Method in interface com.hazelcast.internal.yaml.MutableYamlSequence
Adds a new child node to the sequence
addChild(String, YamlNode) - Method in class com.hazelcast.internal.yaml.YamlMappingImpl
 
addChild(JsonSchemaNameValue) - Method in class com.hazelcast.json.internal.JsonSchemaStructNode
Adds a child node to this Json node.
addClass(String) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
addClass(Class) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
addClassDefinition(ClassDefinition) - Method in class com.hazelcast.config.SerializationConfig
 
addClassDefinition(ClassDefinition) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
addClassDefinition(ClassDefinition) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
addClasses(String...) - Method in class com.hazelcast.config.ClassFilter
 
addClientConfig(ClientConfig) - Method in class com.hazelcast.client.config.ClientFailoverConfig
 
addClientListener(ClientListener) - Method in interface com.hazelcast.client.ClientService
Adds a ClientListener.
addClientListener(ClientListener) - Method in class com.hazelcast.client.impl.ClientServiceProxy
 
addClientPermissionConfig(PermissionConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addClientPermissionConfig(PermissionConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
addCloseListener(ChannelCloseListener) - Method in class com.hazelcast.internal.networking.AbstractChannel
 
addCloseListener(ChannelCloseListener) - Method in interface com.hazelcast.internal.networking.Channel
Adds a ChannelCloseListener.
addConnectionListener(ConnectionListener) - Method in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
addConnectionListener(ConnectionListener) - Method in interface com.hazelcast.internal.nio.ConnectionListenable
Registers a ConnectionListener.
addConnectionListener(ConnectionListener) - Method in class com.hazelcast.internal.nio.DefaultAggregateEndpointManager
 
addConnectionListener(ConnectionListener) - Method in class com.hazelcast.internal.nio.tcp.ClientViewUnifiedEndpointManager
 
addConnectionListener(ConnectionListener) - Method in class com.hazelcast.internal.nio.tcp.MemberViewUnifiedEndpointManager
 
addConnectionListener(ConnectionListener) - Method in class com.hazelcast.internal.nio.tcp.TcpIpEndpointManager
 
addConnectionListener(ConnectionListener) - Method in class com.hazelcast.internal.nio.tcp.TextViewUnifiedEndpointManager
 
addConnectionListener(ConnectionListener) - Method in class com.hazelcast.internal.nio.UnifiedAggregateEndpointManager
 
addContainer(String, CollectionContainer) - Method in class com.hazelcast.collection.impl.collection.CollectionService
 
addContainer(String, QueueContainer) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
AddCPMemberOp - Class in com.hazelcast.cp.internal.raftop.metadata
A RaftOp that adds a new CP member to CP Subsystem.
AddCPMemberOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.AddCPMemberOp
 
AddCPMemberOp(CPMemberInfo) - Constructor for class com.hazelcast.cp.internal.raftop.metadata.AddCPMemberOp
 
addCustomPublisherConfig(CustomWanPublisherConfig) - Method in class com.hazelcast.config.WanReplicationConfig
Adds a custom WAN publisher implementation configuration to this WAN replication.
addDataSerializableFactory(int, DataSerializableFactory) - Method in class com.hazelcast.config.SerializationConfig
 
addDataSerializableFactory(int, DataSerializableFactory) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
addDataSerializableFactory(int, DataSerializableFactory) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
addDataSerializableFactoryClass(int, String) - Method in class com.hazelcast.config.SerializationConfig
 
addDataSerializableFactoryClass(int, Class<? extends DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
 
addDestroyAction(UUID, Callable<Boolean>) - Method in interface com.hazelcast.client.impl.ClientEndpoint
Adds a remove callable to be called when endpoint is destroyed Note: removeDestroyAction should be called when there is no need to destroy action anymore.
addDestroyAction(UUID, Callable<Boolean>) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
addDiscoveryStrategyConfig(DiscoveryStrategyConfig) - Method in class com.hazelcast.config.DiscoveryConfig
Adds an enabled DiscoveryStrategy configuration.
addDiscoveryStrategyConfig(DiscoveryStrategyConfig) - Method in class com.hazelcast.internal.config.DiscoveryConfigReadOnly
 
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.client.impl.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.impl.HazelcastInstanceImpl
 
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
AddDistributedObjectListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task
 
AddDistributedObjectListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
 
addDouble(String, double) - Method in class com.hazelcast.internal.metrics.managementcenter.MetricsCompressor
 
addDoubleArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addDoubleField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addDurableExecutorConfig(DurableExecutorConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
addDurableExecutorConfig(DurableExecutorConfig) - Method in class com.hazelcast.config.Config
Adds the durable executor configuration.
addDurableExecutorConfig(DurableExecutorConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
AddDurableExecutorConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
AddDurableExecutorConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddDurableExecutorConfigMessageTask
 
AddDynamicConfigOperation - Class in com.hazelcast.internal.dynamicconfig
 
AddDynamicConfigOperation() - Constructor for class com.hazelcast.internal.dynamicconfig.AddDynamicConfigOperation
 
AddDynamicConfigOperation(IdentifiedDataSerializable, int) - Constructor for class com.hazelcast.internal.dynamicconfig.AddDynamicConfigOperation
 
AddDynamicConfigOperationSupplier - Class in com.hazelcast.internal.dynamicconfig
Supplier that creates AddDynamicConfigOperations for a given config.
AddDynamicConfigOperationSupplier(ClusterService, IdentifiedDataSerializable) - Constructor for class com.hazelcast.internal.dynamicconfig.AddDynamicConfigOperationSupplier
 
addedCount() - Method in interface com.hazelcast.internal.util.concurrent.Pipe
Returns the number of items added to this pipe since creation.
addEncryptionKeyListener(SecureStore.EncryptionKeyListener) - Method in interface com.hazelcast.spi.impl.securestore.SecureStore
Registers an SecureStore.EncryptionKeyListener to be notified of encryption key changes.
addEndpoint(String) - Method in class com.hazelcast.config.PermissionConfig
 
addEntryListener(MapListener, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
addEntryListener(EntryListener<K, V>, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
addEntryListener(MapListener, K, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
addEntryListener(EntryListener<K, V>, K, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
addEntryListener(EntryListener<K, V>, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
addEntryListener(EntryListener<K, V>, Predicate<K, V>, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
addEntryListener(EntryListener<K, V>, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
addEntryListener(EntryListener<K, V>, K, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
addEntryListener(EntryListener<K, V>) - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
addEntryListener(EntryListener<K, V>, K) - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
addEntryListener(EntryListener<K, V>, Predicate<K, V>) - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
addEntryListener(EntryListener<K, V>, Predicate<K, V>, K) - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
addEntryListener(MapListener, boolean) - Method in interface com.hazelcast.map.IMap
Adds a MapListener for this map.
addEntryListener(EntryListener<K, V>, boolean) - Method in interface com.hazelcast.map.IMap
Deprecated.
addEntryListener(MapListener, K, boolean) - Method in interface com.hazelcast.map.IMap
Adds a MapListener for this map.
addEntryListener(EntryListener<K, V>, K, boolean) - Method in interface com.hazelcast.map.IMap
addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.IMap
Adds a MapListener for this map.
addEntryListener(EntryListener<K, V>, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.IMap
addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.map.IMap
Adds a MapListener for this map.
addEntryListener(EntryListener<K, V>, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.map.IMap
addEntryListener(MapListener, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addEntryListener(EntryListener<K, V>, 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, V>, 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<K, V>, 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<K, V>, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addEntryListener(MapListener, boolean) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
addEntryListener(MapListener, Object, boolean) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
addEntryListener(MapListener, Predicate, boolean) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
addEntryListener(MapListener, Predicate, Object, boolean) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
addEntryListener(MapListener, boolean) - Method in interface com.hazelcast.map.QueryCache
 
addEntryListener(MapListener, K, boolean) - Method in interface com.hazelcast.map.QueryCache
 
addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.QueryCache
 
addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.map.QueryCache
 
addEntryListener(EntryListener<K, V>, boolean) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
addEntryListener(EntryListener<K, V>, K, boolean) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
addEntryListener(EntryListener<K, V>, boolean) - Method in interface com.hazelcast.multimap.MultiMap
Adds an entry listener for this multimap.
addEntryListener(EntryListener<K, V>, K, boolean) - Method in interface com.hazelcast.multimap.MultiMap
Adds the specified entry listener for the specified key.
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
 
addEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Adds an entry listener for this map.
addEntryListener(EntryListener<K, V>, K) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Adds the specified entry listener for the specified key.
addEntryListener(EntryListener<K, V>, Predicate<K, V>) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Adds an continuous entry listener for this map.
addEntryListener(EntryListener<K, V>, Predicate<K, V>, K) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Adds an continuous entry listener for this map.
addEntryListenerConfig(CacheSimpleEntryListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MapConfig
 
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.QueryCacheConfig
Adds EntryListenerConfig to this QueryCacheConfig.
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.ReplicatedMapConfig
 
addEntryListenerConfig(CacheSimpleEntryListenerConfig) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.internal.config.MultiMapConfigReadOnly
 
addEventData(CacheEventData) - Method in class com.hazelcast.cache.impl.CacheEventSet
Helper method for adding multiple CacheEventData into this Set
addEventHandler(long, EventHandler) - Method in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
addEventListener(Object, EventFilter, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
 
addEventListener(EventListener, EventFilter, String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapEventPublishingService
 
addEventToQueryCache(Object) - Method in interface com.hazelcast.map.impl.event.MapEventPublisher
Notifies QueryCache subscribers directly, without publishing an event to other map listeners.
addEventToQueryCache(Object) - Method in class com.hazelcast.map.impl.event.MapEventPublisherImpl
 
addEventToQueryCache(Object) - Method in class com.hazelcast.map.impl.event.QueryCacheEventPublisher
 
addExecutorConfig(ExecutorConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
addExecutorConfig(ExecutorConfig) - Method in class com.hazelcast.config.Config
Adds the executor configuration.
addExecutorConfig(ExecutorConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
AddExecutorConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
AddExecutorConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddExecutorConfigMessageTask
 
addField(FieldDefinitionImpl) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addFieldDef(FieldDefinitionImpl) - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
 
addFilter(String) - Method in class com.hazelcast.config.WanReplicationRef
Adds the class name implementing the CacheWanEventFilter or MapWanEventFilter for filtering outbound WAN replication events.
addFilter(String) - Method in class com.hazelcast.internal.config.WanReplicationRefReadOnly
 
addFirst(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
Inserts collection of elements to the front of this queue.
addFlakeIdGeneratorConfig(ClientFlakeIdGeneratorConfig) - Method in class com.hazelcast.client.config.ClientConfig
Adds a flake ID generator configuration.
addFlakeIdGeneratorConfig(FlakeIdGeneratorConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
addFlakeIdGeneratorConfig(FlakeIdGeneratorConfig) - Method in class com.hazelcast.config.Config
Adds a flake ID generator configuration.
addFlakeIdGeneratorConfig(FlakeIdGeneratorConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
AddFlakeIdGeneratorConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
AddFlakeIdGeneratorConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddFlakeIdGeneratorConfigMessageTask
 
addFloatArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addFloatField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addForcibly(DelayedEntry<Data, Object>) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
Adds delayed-entry without doing capacity checks.
addForcibly(DelayedEntry<Data, Object>) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
addForcibly(DelayedEntry) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
addGetTimeNanos(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Increments the getCache time accumulator.
addIndex(IndexConfig) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
addIndex(IndexType, String...) - Method in interface com.hazelcast.map.IMap
Convenient method to add an index to this map with the given type and attributes.
addIndex(IndexConfig) - Method in interface com.hazelcast.map.IMap
Adds an index to this map for the specified entries so that queries can run faster.
addIndex(IndexConfig) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
addIndex(IndexType, String...) - Method in interface com.hazelcast.map.QueryCache
 
addIndex(IndexConfig) - Method in interface com.hazelcast.map.QueryCache
 
AddIndexBackupOperation - Class in com.hazelcast.map.impl.operation
 
AddIndexBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.AddIndexBackupOperation
 
AddIndexBackupOperation(String, IndexConfig) - Constructor for class com.hazelcast.map.impl.operation.AddIndexBackupOperation
 
addIndexCofigs(Collection<IndexConfig>) - Method in class com.hazelcast.query.impl.MapIndexInfo
 
addIndexConfig(IndexConfig) - Method in class com.hazelcast.config.MapConfig
 
addIndexConfig(IndexConfig) - Method in class com.hazelcast.config.QueryCacheConfig
 
addIndexConfig(IndexConfig) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
addIndexConfig(IndexConfig) - Method in class com.hazelcast.internal.config.QueryCacheConfigReadOnly
 
AddIndexOperation - Class in com.hazelcast.map.impl.operation
 
AddIndexOperation() - Constructor for class com.hazelcast.map.impl.operation.AddIndexOperation
 
AddIndexOperation(String, IndexConfig) - 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, IndexConfig) - Constructor for class com.hazelcast.map.impl.operation.AddIndexOperationFactory
 
addIntArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addInterceptor(MapInterceptor) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
addInterceptor(MapInterceptor) - Method in interface com.hazelcast.map.IMap
Adds an interceptor for this map.
addInterceptor(String, String, MapInterceptor) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
 
addInterceptor(MapInterceptor) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
AddInterceptorOperation - Class in com.hazelcast.map.impl.operation
 
AddInterceptorOperation() - Constructor for class com.hazelcast.map.impl.operation.AddInterceptorOperation
 
AddInterceptorOperation(String, String, MapInterceptor) - Constructor for class com.hazelcast.map.impl.operation.AddInterceptorOperation
 
AddInterceptorOperationSupplier - Class in com.hazelcast.map.impl.operation
 
AddInterceptorOperationSupplier(String, String, MapInterceptor) - Constructor for class com.hazelcast.map.impl.operation.AddInterceptorOperationSupplier
 
addInterface(String) - Method in class com.hazelcast.config.InterfacesConfig
Adds a new interface
addInterface(String) - Method in class com.hazelcast.config.MemberGroupConfig
Adds an interface to the member group.
addIntField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addInvalidationListener(String, CacheEventListener, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
Registers and CacheEventListener for specified cacheNameWithPrefix
addInvalidationListener(String, CacheEventListener, boolean) - Method in interface com.hazelcast.cache.impl.ICacheService
 
addItem(long, Object) - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalReadResultSetImpl
 
addItem(long, Object) - Method in class com.hazelcast.map.impl.journal.MapEventJournalReadResultSetImpl
 
addItem(long, Object) - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
Applies the Projection and adds an item to this ReadResultSetImpl if it passes the Predicate and IFunction with which it was constructed.
addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientSetProxy
 
addItemListener(ItemListener<E>, boolean) - Method in interface com.hazelcast.collection.ICollection
Adds an item listener for this collection.
addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
addItemListener(String, ItemListener, boolean, boolean) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
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.QueueConfig
Add an item listener configuration to this queue.
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.internal.config.ListConfigReadOnly
 
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.internal.config.QueueConfigReadOnly
 
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.internal.config.SetConfigReadOnly
 
additionalCacheConfigSetup(CacheConfig, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
addJar(String) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
String jarPath is searched in following order: 1.
addJar(File) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
addLabel(String) - Method in class com.hazelcast.client.config.ClientConfig
Adds a label for this client Client available
addLast(InboundHandler...) - Method in interface com.hazelcast.internal.networking.InboundPipeline
Adds the handlers at the end of the pipeline.
addLast(InboundHandler...) - Method in class com.hazelcast.internal.networking.nio.NioInboundPipeline
 
addLast(OutboundHandler...) - Method in class com.hazelcast.internal.networking.nio.NioOutboundPipeline
 
addLast(OutboundHandler...) - Method in interface com.hazelcast.internal.networking.OutboundPipeline
Adds the handlers at the end of the pipeline No verification is done if the handler is already added and a handler should only be added once.
addLast(E, boolean) - 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.clientside.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.impl.LifecycleServiceImpl
 
addLifecycleListener(LifecycleListener) - Method in class com.hazelcast.instance.impl.TerminatedLifecycleService
 
addListConfig(ListConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
addListConfig(ListConfig) - Method in class com.hazelcast.config.Config
Adds the list configuration.
addListConfig(ListConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
AddListConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
AddListConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddListConfigMessageTask
 
addListener(String, String, MapListener) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheEventService
 
addListener(String, String, MapListener, EventFilter) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheEventService
 
addListener(String, ListenerAdapter, EventFilter) - Method in class com.hazelcast.client.impl.querycache.subscriber.QueryCacheToListenerMapper
 
addListener(String, String, MapListener) - Method in interface com.hazelcast.map.impl.querycache.QueryCacheEventService
Adds a user-defined listener to a query-cache.
addListener(String, String, MapListener, EventFilter) - Method in interface com.hazelcast.map.impl.querycache.QueryCacheEventService
Adds a user-defined listener to a query-cache.
addListener(String, String, MapListener) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheEventService
 
addListener(String, String, MapListener, EventFilter) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheEventService
 
addListener(String, EventListener, Data, boolean, boolean) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
addListenerAdapter(ListenerAdapter, EventFilter, String) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
addListenerConfig(ListenerConfig) - Method in class com.hazelcast.client.config.ClientConfig
Helper method to add a new ListenerConfig
addListenerConfig(ListenerConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
addListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.Config
Adds a configuration for an EventListener.
addListenerConfig(SplitBrainProtectionListenerConfig) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
addListenerConfig(ListenerConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
addListenerDestroyAction(String, String, UUID) - Method in interface com.hazelcast.client.impl.ClientEndpoint
Adds a remove callable to be called when endpoint is destroyed to clean related listener Following line will be called when endpoint destroyed : eventService.deregisterListener(service, topic, ID); Note: removeDestroyAction should be called when there is no need to destroy action anymore.
addListenerDestroyAction(String, String, UUID) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
addLocalEntryListener(MapListener) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
addLocalEntryListener(EntryListener<K, V>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
addLocalEntryListener(MapListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
addLocalEntryListener(EntryListener<K, V>, Predicate<K, V>, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
addLocalEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
addLocalEntryListener(EntryListener<K, V>, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
addLocalEntryListener(EntryListener<K, V>) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
addLocalEntryListener(MapListener) - Method in interface com.hazelcast.map.IMap
Adds a MapListener for this map.
addLocalEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.map.IMap
Deprecated.
addLocalEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.IMap
Adds a MapListener for this map.
addLocalEntryListener(EntryListener<K, V>, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.IMap
addLocalEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.map.IMap
Adds a local entry listener for this map.
addLocalEntryListener(EntryListener<K, V>, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.map.IMap
addLocalEntryListener(MapListener) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addLocalEntryListener(EntryListener<K, V>) - 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<K, V>, 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<K, V>, 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
 
addLocalEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.multimap.MultiMap
Adds a local entry listener for this multimap.
addLocalEventListener(Object, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
 
addLocalEventListener(Object, EventFilter, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
 
addLocalListenerAdapter(ListenerAdapter, String) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
addLocalPartitionLostListener(PartitionLostListener) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
addLocalPartitionLostListener(PartitionLostListener) - Method in class com.hazelcast.internal.partition.impl.PartitionEventManager
 
addLocalPartitionLostListener(MapPartitionLostListener, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
 
addLocalPartitionLostListener(PartitionLostListener) - Method in interface com.hazelcast.spi.partition.IPartitionService
 
addLockConfig(FencedLockConfig) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Adds the FencedLock configuration.
addLoginModuleConfig(LoginModuleConfig) - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
 
addLogListener(Level, LogListener) - Method in class com.hazelcast.client.impl.clientside.ClientLoggingService
 
addLogListener(Level, LogListener) - Method in class com.hazelcast.logging.impl.LoggingServiceImpl
 
addLogListener(Level, LogListener) - Method in interface com.hazelcast.logging.LoggingService
 
addLong(String, long) - Method in class com.hazelcast.internal.metrics.managementcenter.MetricsCompressor
 
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.client.impl.clientside.ClientDynamicClusterConfig
 
addMapConfig(MapConfig) - Method in class com.hazelcast.config.Config
Adds the map configuration.
addMapConfig(MapConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
AddMapConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
AddMapConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddMapConfigMessageTask
 
addMapEntrySet(Object, Object, MapEntries) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
addMapEntrySet(Map<Object, Object>, MapEntries) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
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(long, CPMemberInfo) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
this method is idempotent
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
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.impl.proxy.ClientClusterProxy
 
addMembershipListener(MembershipListener) - Method in interface com.hazelcast.client.impl.spi.ClientClusterService
 
addMembershipListener(MembershipListener) - Method in class com.hazelcast.client.impl.spi.impl.ClientClusterServiceImpl
 
addMembershipListener(MembershipListener) - Method in interface com.hazelcast.cluster.Cluster
Adds MembershipListener to listen for membership updates.
addMembershipListener(MembershipListener) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
AddMembershipListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task
 
AddMembershipListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
 
addMessageListener(MessageListener<E>) - Method in class com.hazelcast.client.impl.proxy.ClientReliableTopicProxy
 
addMessageListener(MessageListener<E>) - Method in class com.hazelcast.client.impl.proxy.ClientTopicProxy
 
addMessageListener(MessageListener<E>) - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicProxy
 
addMessageListener(MessageListener<E>) - Method in class com.hazelcast.topic.impl.TopicProxy
 
addMessageListener(String, MessageListener, boolean) - Method in class com.hazelcast.topic.impl.TopicService
 
addMessageListener(MessageListener<E>) - Method in interface com.hazelcast.topic.ITopic
Subscribes to this topic.
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.internal.config.ReliableTopicConfigReadOnly
 
addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.internal.config.TopicConfigReadOnly
 
addMessageListenerInternal(MessageListener) - Method in class com.hazelcast.topic.impl.TopicProxySupport
 
addMigrationListener(MigrationListener) - Method in class com.hazelcast.client.impl.proxy.PartitionServiceProxy
 
addMigrationListener(MigrationListener) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
addMigrationListener(MigrationListener) - Method in class com.hazelcast.internal.partition.impl.PartitionEventManager
 
addMigrationListener(MigrationListener) - Method in class com.hazelcast.internal.partition.PartitionServiceProxy
 
addMigrationListener(MigrationListener) - Method in interface com.hazelcast.partition.PartitionService
Adds a MigrationListener.
addMigrationListener(MigrationListener) - Method in interface com.hazelcast.spi.partition.IPartitionService
 
addMulticastListener(MulticastListener) - Method in class com.hazelcast.internal.cluster.impl.MulticastService
 
addMultiMapConfig(MultiMapConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
addMultiMapConfig(MultiMapConfig) - Method in class com.hazelcast.config.Config
Adds the multimap configuration.
addMultiMapConfig(MultiMapConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
AddMultiMapConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
AddMultiMapConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddMultiMapConfigMessageTask
 
addNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.client.config.ClientConfig
Helper method to add a new NearCacheConfig
addNearCacheInvalidationListener(EventHandler) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
addNearCacheInvalidationListener(EventHandler) - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
addNearCacheInvalidationListener(EventHandler) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
addNearCacheInvalidationListener(InvalidationListener) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
addNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
 
addNullOrEmptyTarget() - Method in class com.hazelcast.query.impl.getters.ImmutableMultiResult
 
addNullOrEmptyTarget() - Method in class com.hazelcast.query.impl.getters.MultiResult
 
addObject(T) - Method in interface com.hazelcast.query.extractor.ValueCollector
Collects a value passed as an argument
addObject(Object) - Method in class com.hazelcast.query.impl.DefaultValueCollector
 
addOperation(CollectionTxnOperation) - Method in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
 
AddOperation - Class in com.hazelcast.internal.crdt.pncounter.operations
Addition/subtraction operation for a PNCounter.
AddOperation(String, long, boolean, VectorClock) - Constructor for class com.hazelcast.internal.crdt.pncounter.operations.AddOperation
Creates the addition operation.
AddOperation() - Constructor for class com.hazelcast.internal.crdt.pncounter.operations.AddOperation
 
addOperation(Operation) - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
 
AddOperation - Class in com.hazelcast.ringbuffer.impl.operations
Adds a new ring buffer item.
AddOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddOperation
 
AddOperation(String, Data, OverflowPolicy) - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddOperation
 
addOpToCancel(Address, long) - Method in class com.hazelcast.spi.impl.operationservice.CallsPerMember
 
addOrGetIndex(IndexConfig, StoreAdapter) - Method in class com.hazelcast.query.impl.Indexes
 
addOrVote(T) - Method in class com.hazelcast.internal.util.collection.WeightedEvictableList
Adds a new item to the list or votes for the given item if it already exists.
addOrVoteForPattern(JsonPattern) - Method in class com.hazelcast.query.impl.getters.JsonGetterContext
 
addOutboundPort(int) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Add outbound port to the outbound port list
addOutboundPort(int) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
addOutboundPort(int) - Method in class com.hazelcast.config.EndpointConfig
 
addOutboundPort(int) - Method in class com.hazelcast.config.NetworkConfig
 
addOutboundPort(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
addOutboundPortDefinition(String) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Add outbound port definition to the outbound port definition list
addOutboundPortDefinition(String) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
addOutboundPortDefinition(String) - Method in class com.hazelcast.config.EndpointConfig
 
addOutboundPortDefinition(String) - Method in class com.hazelcast.config.NetworkConfig
 
addOutboundPortDefinition(String) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
addPackages(String...) - Method in class com.hazelcast.config.ClassFilter
 
addParam(String, String) - Method in class com.hazelcast.internal.util.PhoneHome.PhoneHomeParameterCreator
 
addParameter(String, Object) - Method in interface com.hazelcast.internal.auditlog.EventBuilder
Adds single event parameter to the parameters Map.
addParameter(String, Object) - Method in class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService.Builder
 
AddPartitionListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task
 
AddPartitionListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AddPartitionListenerMessageTask
 
addPartitionLostListener(CachePartitionLostListener) - Method in interface com.hazelcast.cache.ICache
Adds a CachePartitionLostListener.
addPartitionLostListener(CachePartitionLostListener) - Method in class com.hazelcast.cache.impl.CacheProxy
 
addPartitionLostListener(CachePartitionLostListener) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
addPartitionLostListener(MapPartitionLostListener) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
addPartitionLostListener(PartitionLostListener) - Method in class com.hazelcast.client.impl.proxy.PartitionServiceProxy
 
addPartitionLostListener(PartitionLostListener) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
addPartitionLostListener(PartitionLostListener) - Method in class com.hazelcast.internal.partition.impl.PartitionEventManager
 
addPartitionLostListener(PartitionLostListener) - Method in class com.hazelcast.internal.partition.PartitionServiceProxy
 
addPartitionLostListener(MapPartitionLostListener) - Method in interface com.hazelcast.map.IMap
Adds a MapPartitionLostListener.
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 interface com.hazelcast.partition.PartitionService
Adds a PartitionLostListener.
addPartitionLostListener(PartitionLostListener) - Method in interface com.hazelcast.spi.partition.IPartitionService
 
AddPartitionLostListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task
 
AddPartitionLostListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
 
addPersistence(long, int, int) - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
addPersistenceFailure(Throwable) - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
addPNCounterConfig(PNCounterConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
addPNCounterConfig(PNCounterConfig) - Method in class com.hazelcast.config.Config
Adds the PN counter configuration.
addPNCounterConfig(PNCounterConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
addPortableArrayField(String, ClassDefinition) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addPortableFactory(int, PortableFactory) - Method in class com.hazelcast.config.SerializationConfig
 
addPortableFactory(int, PortableFactory) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
addPortableFactory(int, PortableFactory) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
addPortableFactoryClass(int, Class<? extends PortableFactory>) - Method in class com.hazelcast.config.SerializationConfig
 
addPortableFactoryClass(int, String) - Method in class com.hazelcast.config.SerializationConfig
 
addPortableField(String, ClassDefinition) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addPrefixes(String...) - Method in class com.hazelcast.config.ClassFilter
 
addProperty(String, Comparable) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
addProperty(String, String) - Method in class com.hazelcast.config.ServiceConfig
 
addProxyFactoryConfig(ProxyFactoryConfig) - Method in class com.hazelcast.client.config.ClientConfig
Helper method to add a new ProxyFactoryConfig
addProxyListener(DistributedObjectListener) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
 
addProxyListener(DistributedObjectListener) - Method in interface com.hazelcast.spi.impl.proxyservice.ProxyService
 
addPublisher(String, WanReplicationPublisher) - Method in class com.hazelcast.wan.impl.DelegatingWanReplicationScheme
 
addPublisherListener(String, String, ListenerAdapter) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheEventService
 
addPublisherListener(String, String, ListenerAdapter) - Method in interface com.hazelcast.map.impl.querycache.QueryCacheEventService
Adds the listener to listen underlying IMap on all nodes.
addPublisherListener(String, String, ListenerAdapter) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheEventService
 
addPutTimeNanos(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Increments the put time accumulator.
addQuery(long, Object, InternalCompletableFuture) - Method in class com.hazelcast.cp.internal.raft.impl.state.QueryState
Adds the given query to the collection of queries and returns the number of queries waiting to be executed.
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.client.impl.clientside.ClientDynamicClusterConfig
 
addQueueConfig(QueueConfig) - Method in class com.hazelcast.config.Config
Adds the queue configuration.
addQueueConfig(QueueConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
AddQueueConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
AddQueueConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddQueueConfigMessageTask
 
addRealmConfig(String, RealmConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addRealmConfig(String, RealmConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
addRegistration(String, Registration) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceSegment
Adds a registration for the topic and notifies the listener and service of the listener registration.
addReliableTopicConfig(ClientReliableTopicConfig) - Method in class com.hazelcast.client.config.ClientConfig
Adds a ClientReliableTopicConfig.
addReliableTopicConfig(ReliableTopicConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
addReliableTopicConfig(ReliableTopicConfig) - Method in class com.hazelcast.config.Config
Adds the reliable topic configuration.
addReliableTopicConfig(ReliableTopicConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
AddReliableTopicConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
AddReliableTopicConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddReliableTopicConfigMessageTask
 
addRemoveTimeNanos(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Increments the remove time accumulator.
addReplicatedMapConfig(ReplicatedMapConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
addReplicatedMapConfig(ReplicatedMapConfig) - Method in class com.hazelcast.config.Config
Adds the replicated map configuration.
addReplicatedMapConfig(ReplicatedMapConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
AddReplicatedMapConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
AddReplicatedMapConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddReplicatedMapConfigMessageTask
 
address - Variable in class com.hazelcast.client.impl.protocol.codec.CacheFetchNearCacheInvalidationMetadataCodec.RequestParameters
TODO DOC
address - Variable in class com.hazelcast.client.impl.protocol.codec.CacheListenerRegistrationCodec.RequestParameters
The address of the member server for which the listener is being registered for.
address - Variable in class com.hazelcast.client.impl.protocol.codec.CacheManagementConfigCodec.RequestParameters
the address of the host to enable.
address - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec.ResponseParameters
TODO DOC
address - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec.ResponseParameters
TODO DOC
address - Variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnAddressCodec.RequestParameters
Address of the host to execute the request on.
address - Variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToAddressCodec.RequestParameters
The member host on which the callable shall be executed on.
address - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchNearCacheInvalidationMetadataCodec.RequestParameters
TODO DOC
address - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromAddressCodec.RequestParameters
The address of the member where the task will get scheduled.
address - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromAddressCodec.RequestParameters
The address of the member where the task will get scheduled.
address - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromAddressCodec.RequestParameters
The address of the member where the task will get scheduled.
address - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromAddressCodec.RequestParameters
The address of the member where the task will get scheduled.
address - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromAddressCodec.RequestParameters
The address of the member where the task will get scheduled.
address - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromAddressCodec.RequestParameters
The address of the member where the task will get scheduled.
address - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromAddressCodec.RequestParameters
The address of the member where the task will get scheduled.
address - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorShutdownCodec.RequestParameters
The cluster member where the shutdown for this scheduler will be sent.
address - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToAddressCodec.RequestParameters
The address of the member where the task will get scheduled.
Address - Class in com.hazelcast.cluster
Represents an address of a member in the cluster.
Address() - Constructor for class com.hazelcast.cluster.Address
 
Address(String, int) - Constructor for class com.hazelcast.cluster.Address
 
Address(InetAddress, int) - Constructor for class com.hazelcast.cluster.Address
 
Address(InetSocketAddress) - Constructor for class com.hazelcast.cluster.Address
Creates a new Address
Address(String, InetAddress, int) - Constructor for class com.hazelcast.cluster.Address
 
Address(Address) - Constructor for class com.hazelcast.cluster.Address
 
address - Variable in class com.hazelcast.cluster.impl.AbstractMember
 
address - Variable in class com.hazelcast.instance.impl.Node
Member-to-member address only.
ADDRESS - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
address - Variable in class com.hazelcast.internal.cluster.impl.JoinMessage
 
address - Variable in class com.hazelcast.internal.management.dto.ClientEndPointDTO
Client's socket address as "hostname:port"
address() - Method in class com.hazelcast.internal.partition.PartitionReplica
 
address - Variable in class com.hazelcast.internal.util.AddressUtil.AddressMatcher
 
address() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray
 
address() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
address() - Method in class com.hazelcast.internal.util.hashslot.impl.SlotAssignmentResultImpl
 
address() - Method in interface com.hazelcast.internal.util.hashslot.SlotAssignmentResult
 
AddressCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
Addresses - Class in com.hazelcast.client.impl.connection
A collection of addresses.
Addresses() - Constructor for class com.hazelcast.client.impl.connection.Addresses
 
Addresses(Collection<Address>) - Constructor for class com.hazelcast.client.impl.connection.Addresses
 
addresses() - Method in class com.hazelcast.spi.impl.operationservice.CallsPerMember
 
AddressHelper - Class in com.hazelcast.client.util
This is a client side utility class for working with addresses and cluster connections
AddressHolder(String, int, String) - Constructor for class com.hazelcast.internal.util.AddressUtil.AddressHolder
 
addressMap - Variable in class com.hazelcast.cluster.impl.AbstractMember
 
AddressMatcher(String[]) - Constructor for class com.hazelcast.internal.util.AddressUtil.AddressMatcher
 
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.impl.connection
Provides initial addresses for client to find and connect to a node & Translates given address if necessary when connecting a service
AddressUtil - Class in com.hazelcast.internal.util
AddressUtil contains Address helper methods.
AddressUtil.AddressHolder - Class in com.hazelcast.internal.util
Holds address
AddressUtil.AddressMatcher - Class in com.hazelcast.internal.util
http://docs.oracle.com/javase/1.5.0/docs/guide/net/ipv6_guide/index.html
AddressUtil.InvalidAddressException - Exception in com.hazelcast.internal.util
Thrown when given address is not valid.
addResults(Map<Integer, Object>) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation.PartitionResponse
 
addResultSet(Map<Data, QueryableEntry>) - Method in class com.hazelcast.query.impl.DuplicateDetectingMultiResult
 
addResultSet(Map<Data, QueryableEntry>) - Method in class com.hazelcast.query.impl.FastMultiResultSet
 
addResultSet(Map<Data, QueryableEntry>) - Method in interface com.hazelcast.query.impl.MultiResultSet
TODO
addRingbuffer(int, RingbufferContainer, RingbufferConfig) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
addRingBufferConfig(RingbufferConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
addRingBufferConfig(RingbufferConfig) - Method in class com.hazelcast.config.Config
Adds the ringbuffer configuration.
addRingBufferConfig(RingbufferConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
AddRingbufferConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
AddRingbufferConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddRingbufferConfigMessageTask
 
addrOfKey1At(long) - Static method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyImpl
 
addrOfKey2At(long) - Static method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyImpl
 
addrOfValueAt(long) - Static method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyImpl
 
addRow(QueryResultRow) - Method in class com.hazelcast.map.impl.query.QueryResult
Adds the given row into this result.
addScheduledExecutorConfig(ScheduledExecutorConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
addScheduledExecutorConfig(ScheduledExecutorConfig) - Method in class com.hazelcast.config.Config
Adds the scheduled executor configuration.
addScheduledExecutorConfig(ScheduledExecutorConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
AddScheduledExecutorConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
AddScheduledExecutorConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddScheduledExecutorConfigMessageTask
 
addSecurityInterceptorConfig(SecurityInterceptorConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addSecurityInterceptorConfig(SecurityInterceptorConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
addSemaphoreConfig(SemaphoreConfig) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Adds the CP ISemaphore configuration.
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.client.impl.clientside.ClientDynamicClusterConfig
 
addSetConfig(SetConfig) - Method in class com.hazelcast.config.Config
Adds the set configuration.
addSetConfig(SetConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
AddSetConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
AddSetConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddSetConfigMessageTask
 
addShortArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addShortField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addSplitBrainProtectionConfig(SplitBrainProtectionConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
addSplitBrainProtectionConfig(SplitBrainProtectionConfig) - Method in class com.hazelcast.config.Config
Adds the split-brain protection configuration.
addSplitBrainProtectionConfig(SplitBrainProtectionConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
addSplitBrainProtectionListener(String, SplitBrainProtectionListener) - Method in class com.hazelcast.splitbrainprotection.impl.SplitBrainProtectionServiceImpl
 
addStoreListener(StoreListener) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
 
addStructureStats(String, LocalMapStatsProvider.LocalMapOnDemandCalculatedStats) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
Adds stats related to the data structure itself that should be reported even if the map or some of its RecordStore is empty
addTask(Runnable) - Method in class com.hazelcast.internal.networking.nio.NioThread
Adds a task to this NioThread without notifying the thread.
addTaskAndWakeup(Runnable) - Method in class com.hazelcast.internal.networking.nio.NioThread
Adds a task to be executed by the NioThread and wakes up the selector so that it will eventually pick up the task.
addTopicConfig(TopicConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
addTopicConfig(TopicConfig) - Method in class com.hazelcast.config.Config
Adds the topic configuration.
addTopicConfig(TopicConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
AddTopicConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
AddTopicConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddTopicConfigMessageTask
 
addToValueList(Map<K, List<V>>, K, V) - Static method in class com.hazelcast.internal.util.CollectionUtil
Adds a value to a list of values in the map.
addTransient(K, long) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
 
addTransient(Data, long) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
addTransient(Data, long) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
addTrustedInterface(String) - Method in class com.hazelcast.config.MulticastConfig
Adds a trusted interface.
addUTFArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addUTFField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addWaitKey(Object, W) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.BlockingResource
 
addWaitKey(String, W, long) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
addWanBatchReplicationPublisherConfig(WanBatchReplicationPublisherConfig) - Method in class com.hazelcast.config.WanReplicationConfig
Adds a WAN publisher configuration using the built-in batching WAN implementation to this WAN replication.
AddWanConfigIgnoredEvent - Class in com.hazelcast.internal.management.events
 
AddWanConfigResult - Class in com.hazelcast.wan.impl
The result of adding WAN configuration.
AddWanConfigResult(Collection<String>, Collection<String>) - Constructor for class com.hazelcast.wan.impl.AddWanConfigResult
 
addWanEndpointConfig(EndpointConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
Adds the given WAN EndpointConfig to the endpoints configuration.
addWanReplicationConfig(WanReplicationConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
addWanReplicationConfig(WanReplicationConfig) - Method in class com.hazelcast.config.Config
Adds the WAN replication config under the name defined by WanReplicationConfig.getName().
addWanReplicationConfig(WanReplicationConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
addWanReplicationConfig(WanReplicationConfig) - Method in interface com.hazelcast.wan.impl.WanReplicationService
Adds a new WanReplicationConfig to the cluster.
addWanReplicationConfig(WanReplicationConfig) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
 
addWanReplicationConfigLocally(WanReplicationConfig) - Method in interface com.hazelcast.wan.impl.WanReplicationService
Adds a new WanReplicationConfig to this member and creates the WanReplicationPublishers specified in the config.
addWanReplicationConfigLocally(WanReplicationConfig) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
 
addWithoutEvictionCheck(Data, Data) - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordStore
 
adjustEstimateBy(long) - Method in interface com.hazelcast.map.impl.EntryCostEstimator
Adjust the memory cost estimation by the given adjustment.
adjustThrowable(Throwable) - Method in class com.hazelcast.client.impl.proxy.ClientReliableMessageRunner
 
adjustThrowable(Throwable) - Method in class com.hazelcast.topic.impl.reliable.MessageRunner
Needed because client / server behaviour is different on onFailure call
adjustThrowable(Throwable) - Method in class com.hazelcast.topic.impl.reliable.ReliableMessageRunner
 
advance() - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
advance() - Method in class com.hazelcast.cache.impl.CachePartitionIterator
 
advance() - Method in class com.hazelcast.client.cache.impl.ClientCachePartitionIterator
 
advance() - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap.LongLongCursor
 
advance() - Method in interface com.hazelcast.internal.util.collection.LongCursor
Advances to the next long element.
advance() - Method in interface com.hazelcast.internal.util.collection.LongLongCursor
Advances to the next map entry.
advance() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotCursor
Advances to the next assigned slot.
advance() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase.Cursor
 
advance() - Method in class com.hazelcast.map.impl.iterator.AbstractMapPartitionIterator
 
advance() - Method in class com.hazelcast.map.impl.iterator.AbstractMapQueryPartitionIterator
 
AdvancedNetworkConfig - Class in com.hazelcast.config
Similar to NetworkConfig with the additional ability to define multiple endpoints, each with its own separate protocol/security and/or socket properties.
AdvancedNetworkConfig() - Constructor for class com.hazelcast.config.AdvancedNetworkConfig
 
AdvancedNetworkConfig.MemberNetworkingView - Class in com.hazelcast.config
Member endpoint decorated as a NetworkConfig Facade used during bootstrap to hide if-logic between the two networking configuration approaches
after(List<Operation>) - Static method in class com.hazelcast.collection.impl.CollectionTxnUtil
 
after(Credentials, String, String, String, Parameters) - Method in interface com.hazelcast.security.SecurityInterceptor
 
afterClusterStateChange(ClusterState, ClusterState, boolean) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
afterClusterStateChange(ClusterState, ClusterState, boolean) - Method in interface com.hazelcast.instance.impl.NodeExtension
Called after the cluster state change transaction has completed (successfully or otherwise).
afterExecute(Runnable, Throwable) - Method in class com.hazelcast.internal.util.executor.LoggingScheduledExecutor
 
afterGet(Object) - Method in interface com.hazelcast.map.MapInterceptor
Called after the get(...) operation is completed.
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.protocol.task.AbstractAddressMessageTask
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.
afterResponse() - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsKeyMessageTask
 
afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
 
afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheClearExpiredOperation
 
afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
 
afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
 
afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheExpireBatchBackupOperation
 
afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
 
afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
 
afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheOperation
 
afterRun() - Method in class com.hazelcast.cache.impl.operation.CachePutBackupOperation
 
afterRun() - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
 
afterRun() - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
 
afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
 
afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
 
afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
 
afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheSetExpiryPolicyBackupOperation
 
afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheSetExpiryPolicyOperation
 
afterRun() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
 
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.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.QueueMergeBackupOperation
 
afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.QueueMergeOperation
 
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.CollectionCommitBackupOperation
 
afterRun() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitOperation
 
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.TxnCommitBackupOperation
 
afterRun() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitOperation
 
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.internal.cluster.impl.operations.FinalizeJoinOp
 
afterRun() - Method in class com.hazelcast.internal.cluster.impl.operations.SplitBrainMergeValidationOp
 
afterRun() - Method in class com.hazelcast.internal.crdt.AbstractCRDTReplicationOperation
 
afterRun() - Method in class com.hazelcast.internal.util.executor.HazelcastManagedThread
Called after inner run method and can be overridden to customize.
afterRun() - Method in class com.hazelcast.internal.util.executor.PoolExecutorThreadFactory.ManagedThread
 
afterRun() - Method in class com.hazelcast.map.impl.operation.MapClearExpiredOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.MapOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.MapReplicationOperation
 
afterRun() - Method in class com.hazelcast.multimap.impl.operations.ClearOperation
 
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.replicatedmap.impl.operation.PutOperation
 
afterRun() - Method in class com.hazelcast.replicatedmap.impl.operation.RemoveOperation
 
afterRun() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateToCallerOperation
 
afterRun() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
 
afterRun() - Method in class com.hazelcast.spi.impl.operationservice.Operation
Is executed called after Operation.run() or Operation.call() method completes normally and the operation is not blocked, see CallStatus.WAIT.
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.BasePutOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.ClearOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.DeleteOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.EvictBackupOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.EvictOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.GetOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.LoadAllOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.MapOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.MergeOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllBackupOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.PutIfAbsentOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.RemoveBackupOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.RemoveIfSameOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.RemoveOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.ReplaceOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.SetOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.SetTtlBackupOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.SetTtlOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
 
afterRunInternal() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
 
afterStart(HazelcastClientInstanceImpl) - Method in interface com.hazelcast.client.impl.ClientExtension
Called after node is started
afterStart(HazelcastClientInstanceImpl) - Method in class com.hazelcast.client.impl.clientside.DefaultClientExtension
 
afterStart() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
afterStart() - Method in interface com.hazelcast.instance.impl.NodeExtension
Called after node is started
aggregate() - Method in class com.hazelcast.aggregation.Aggregator
Returns the result of the aggregation.
aggregate() - Method in class com.hazelcast.aggregation.impl.BigDecimalAverageAggregator
 
aggregate() - Method in class com.hazelcast.aggregation.impl.BigDecimalSumAggregator
 
aggregate() - Method in class com.hazelcast.aggregation.impl.BigIntegerAverageAggregator
 
aggregate() - Method in class com.hazelcast.aggregation.impl.BigIntegerSumAggregator
 
aggregate() - Method in class com.hazelcast.aggregation.impl.CountAggregator
 
aggregate() - Method in class com.hazelcast.aggregation.impl.DistinctValuesAggregator
 
aggregate() - Method in class com.hazelcast.aggregation.impl.DoubleAverageAggregator
 
aggregate() - Method in class com.hazelcast.aggregation.impl.DoubleSumAggregator
 
aggregate() - Method in class com.hazelcast.aggregation.impl.FixedSumAggregator
 
aggregate() - Method in class com.hazelcast.aggregation.impl.FloatingPointSumAggregator
 
aggregate() - Method in class com.hazelcast.aggregation.impl.IntegerAverageAggregator
 
aggregate() - Method in class com.hazelcast.aggregation.impl.IntegerSumAggregator
 
aggregate() - Method in class com.hazelcast.aggregation.impl.LongAverageAggregator
 
aggregate() - Method in class com.hazelcast.aggregation.impl.LongSumAggregator
 
aggregate() - Method in class com.hazelcast.aggregation.impl.MaxAggregator
 
aggregate() - Method in class com.hazelcast.aggregation.impl.MaxByAggregator
 
aggregate() - Method in class com.hazelcast.aggregation.impl.MinAggregator
 
aggregate() - Method in class com.hazelcast.aggregation.impl.MinByAggregator
 
aggregate() - Method in class com.hazelcast.aggregation.impl.NumberAverageAggregator
 
aggregate(Aggregator<? super Map.Entry<K, V>, R>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
aggregate(Aggregator<? super Map.Entry<K, V>, R>, Predicate<K, V>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
aggregate(Map<K, V>, Map<K, V>) - Static method in class com.hazelcast.internal.dynamicconfig.AggregatingMap
Creates new aggregating maps.
aggregate(Aggregator<? super Map.Entry<K, V>, R>) - Method in interface com.hazelcast.map.IMap
Applies the aggregation logic on all map entries and returns the result
aggregate(Aggregator<? super Map.Entry<K, V>, R>, Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
Applies the aggregation logic on map entries filtered with the Predicated and returns the result
aggregate(Aggregator<? super Map.Entry<K, V>, R>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
aggregate(Aggregator<? super Map.Entry<K, V>, R>, Predicate<K, V>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
AGGREGATE_BACKUP - Static variable in class com.hazelcast.cardinality.impl.CardinalityEstimatorDataSerializerHook
 
AggregateBackupOperation - Class in com.hazelcast.cardinality.impl.operations
 
AggregateBackupOperation() - Constructor for class com.hazelcast.cardinality.impl.operations.AggregateBackupOperation
 
AggregateBackupOperation(String, long) - Constructor for class com.hazelcast.cardinality.impl.operations.AggregateBackupOperation
 
AggregateEndpointManager - Interface in com.hazelcast.internal.nio
 
AggregateOperation - Class in com.hazelcast.cardinality.impl.operations
 
AggregateOperation() - Constructor for class com.hazelcast.cardinality.impl.operations.AggregateOperation
 
AggregateOperation(String, long) - Constructor for class com.hazelcast.cardinality.impl.operations.AggregateOperation
 
AggregatingMap<K,V> - Class in com.hazelcast.internal.dynamicconfig
Provides unmodifiable view aggregating 2 maps with distinct key sets.
AGGREGATION_ACCUMULATION_PARALLEL_EVALUATION - Static variable in class com.hazelcast.spi.properties.GroupProperty
Run aggregation accumulation for multiple entries in parallel.
AGGREGATION_RESULT - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
AggregationResult - Class in com.hazelcast.map.impl.query
Contains the result of the evaluation of an aggregation on a specific Partition or Node.
AggregationResult() - Constructor for class com.hazelcast.map.impl.query.AggregationResult
 
AggregationResult(Aggregator, SerializationService) - Constructor for class com.hazelcast.map.impl.query.AggregationResult
 
AggregationResultProcessor - Class in com.hazelcast.map.impl.query
Responsible for populating AggregationResults
AggregationResultProcessor(AccumulationExecutor, SerializationService) - Constructor for class com.hazelcast.map.impl.query.AggregationResultProcessor
 
Aggregator<I,R> - Class in com.hazelcast.aggregation
Base class for all aggregators.
Aggregator() - Constructor for class com.hazelcast.aggregation.Aggregator
 
aggregator - Variable in class com.hazelcast.client.impl.protocol.codec.MapAggregateCodec.RequestParameters
aggregator to aggregate the entries with
aggregator - Variable in class com.hazelcast.client.impl.protocol.codec.MapAggregateWithPredicateCodec.RequestParameters
aggregator to aggregate the entries with
aggregator(Aggregator) - Method in class com.hazelcast.map.impl.query.Query.QueryBuilder
 
AGGREGATOR_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
AGGREGATOR_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
AggregatorDataSerializerHook - Class in com.hazelcast.aggregation.impl
 
AggregatorDataSerializerHook() - Constructor for class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
Aggregators - Class in com.hazelcast.aggregation
A utility class to create basic Aggregator instances.
AliasedDiscoveryConfig<T extends AliasedDiscoveryConfig<T>> - Class in com.hazelcast.config
Configuration for discovery strategy aliases, e.g.
AliasedDiscoveryConfig(String) - Constructor for class com.hazelcast.config.AliasedDiscoveryConfig
 
AliasedDiscoveryConfig(AliasedDiscoveryConfig) - Constructor for class com.hazelcast.config.AliasedDiscoveryConfig
 
AliasedDiscoveryConfigDTO - Class in com.hazelcast.internal.management.dto
A JSON representation of a AliasedDiscoveryConfig implementation.
AliasedDiscoveryConfigDTO(String) - Constructor for class com.hazelcast.internal.management.dto.AliasedDiscoveryConfigDTO
 
AliasedDiscoveryConfigDTO(AliasedDiscoveryConfig) - Constructor for class com.hazelcast.internal.management.dto.AliasedDiscoveryConfigDTO
 
aliasedDiscoveryConfigsFrom(ClientNetworkConfig) - Static method in class com.hazelcast.client.config.ClientAliasedDiscoveryConfigUtils
Gets a list of all aliased discovery configs from config.
aliasedDiscoveryConfigsFrom(JoinConfig) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Gets a list of all aliased discovery configs from config.
aliasedDiscoveryConfigsFrom(WanBatchReplicationPublisherConfig) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Gets a list of all aliased discovery configs from config.
AliasedDiscoveryConfigUtils - Class in com.hazelcast.config
Utility class for Aliased Discovery Configs.
AlignmentAwareMemoryAccessor - Class in com.hazelcast.internal.memory.impl
Aligned MemoryAccessor which checks for and handles unaligned memory access by splitting a larger-size memory operation into several smaller-size ones (which have finer-grained alignment requirements).
AlignmentUtil - Class in com.hazelcast.internal.memory.impl
 
alive - Variable in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
ALL_ACCEPTED_SUFFIXES - Static variable in class com.hazelcast.internal.config.DeclarativeConfigUtil
Array of the suffixes accepted in Hazelcast configuration files.
ALL_ACCEPTED_SUFFIXES_STRING - Static variable in class com.hazelcast.internal.config.DeclarativeConfigUtil
The list of the suffixes accepted in Hazelcast configuration files.
ALL_NODES - Static variable in class com.hazelcast.map.impl.query.Target
 
allDone(Collection<Future>) - Static method in class com.hazelcast.internal.util.FutureUtil
Check if all futures are done
allocate(long) - Method in interface com.hazelcast.internal.memory.MemoryAllocator
Allocates a block of addresses with the requested size and returns the base address of the block.
allocateArrayAndAdjustFields(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
AllowedDuringPassiveState - Interface in com.hazelcast.spi.impl
Marker interface for operations those are allowed to be executed or invoked during Node's NodeState.PASSIVE state.
AllowedDuringPassiveStateTransactionImpl - Class in com.hazelcast.transaction.impl
 
AllowedDuringPassiveStateTransactionImpl(TransactionManagerServiceImpl, NodeEngine, TransactionOptions, UUID) - Constructor for class com.hazelcast.transaction.impl.AllowedDuringPassiveStateTransactionImpl
 
AllowingTextProtocolFilter - Class in com.hazelcast.internal.nio.ascii
This class is an all allowing implementation of TextProtocolFilter.
AllowingTextProtocolFilter() - Constructor for class com.hazelcast.internal.nio.ascii.AllowingTextProtocolFilter
 
allowsLock(UUID) - Method in class com.hazelcast.internal.util.LockGuard
 
allowsUnlock(UUID) - Method in class com.hazelcast.internal.util.LockGuard
 
allowUnsafe - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
allPartitionIds(int) - Static method in class com.hazelcast.internal.util.SetUtil
 
AllPermissions - Class in com.hazelcast.security.permission
 
AllPermissions() - Constructor for class com.hazelcast.security.permission.AllPermissions
 
AllPermissions.AllPermissionsCollection - Class in com.hazelcast.security.permission
 
AllPermissionsCollection() - Constructor for class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
AllPermissionsCollection(boolean) - Constructor for class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
allUsePublicAddress(List<AliasedDiscoveryConfig<?>>) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Checks whether all aliased discovery configs have the tag <use-public-ip>true</use-public-ip.
alreadyExists(String) - Static method in class com.hazelcast.internal.management.events.AddWanConfigIgnoredEvent
 
alter(IFunction<Long, Long>) - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
alter(IFunction<T, T>) - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
alter - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefApplyCodec.RequestParameters
Denotes whether result of the function will be set to the IAtomicRefInstance
alter(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
Alters the currently stored value by applying a function on it.
alter(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
Alters the currently stored reference by applying a function on it.
alter(IFunction<Long, Long>) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
alter(IFunction<T, T>) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
alter(IFunction<Long, Long>) - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
alter(IFunction<Long, Long>) - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
ALTER_OP - Static variable in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongDataSerializerHook
 
alterAndGet(IFunction<Long, Long>) - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
alterAndGet(IFunction<T, T>) - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
alterAndGet(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.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.cp.IAtomicReference
Alters the currently stored reference by applying a function on it and gets the result.
alterAndGet(IFunction<Long, Long>) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
alterAndGet(IFunction<T, T>) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
alterAndGet(IFunction<Long, Long>) - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
alterAndGet(IFunction<Long, Long>) - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
alterAndGetAsync(IFunction<Long, Long>) - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
alterAndGetAsync(IFunction<T, T>) - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
alterAndGetAsync(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
Alters the currently stored value by applying a function on it and gets the result.
alterAndGetAsync(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
Alters the currently stored reference by applying a function on it and gets the result.
alterAndGetAsync(IFunction<Long, Long>) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
alterAndGetAsync(IFunction<T, T>) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
alterAndGetAsync(IFunction<Long, Long>) - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
alterAndGetAsync(IFunction<Long, Long>) - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
alterAsync(IFunction<Long, Long>) - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
alterAsync(IFunction<T, T>) - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
alterAsync(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
Alters the currently stored value by applying a function on it.
alterAsync(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
Alters the currently stored reference by applying a function on it.
alterAsync(IFunction<Long, Long>) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
alterAsync(IFunction<T, T>) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
alterAsync(IFunction<Long, Long>) - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
alterAsync(IFunction<Long, Long>) - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
AlterMessageTask - Class in com.hazelcast.cp.internal.datastructures.atomiclong.client
Client message task for AlterOp
AlterMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.client.AlterMessageTask
 
AlterOp - Class in com.hazelcast.cp.internal.datastructures.atomiclong.operation
AlterOp() - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.operation.AlterOp
 
AlterOp(String, IFunction<Long, Long>, AlterOp.AlterResultType) - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.operation.AlterOp
 
AlterOp.AlterResultType - Enum in com.hazelcast.cp.internal.datastructures.atomiclong.operation
Denotes how the return value will be chosen.
ALWAYS_FRESH - Static variable in interface com.hazelcast.internal.nearcache.impl.invalidation.StaleReadDetector
This instance will be used when Near Cache invalidations are disabled.
AlwaysApplyFilter<T> - Class in com.hazelcast.internal.util.filter
Always matching filter
alwaysFalse() - Static method in interface com.hazelcast.internal.util.function.PredicateEx
Returns a predicate that always evaluates to false.
alwaysFalse() - Static method in class com.hazelcast.query.Predicates
Creates an always false predicate that will filter out all items.
alwaysTrue() - Static method in interface com.hazelcast.internal.util.function.PredicateEx
Returns a predicate that always evaluates to true.
alwaysTrue() - Static method in class com.hazelcast.query.Predicates
Creates an always true predicate that will pass all items.
AMEM - Static variable in class com.hazelcast.internal.memory.GlobalMemoryAccessorRegistry
Like GlobalMemoryAccessorRegistry.MEM, but an instance specialized for aligned memory access.
AMEM_AVAILABLE - Static variable in class com.hazelcast.internal.memory.GlobalMemoryAccessorRegistry
If this constant is true, then GlobalMemoryAccessorRegistry.AMEM refers to a usable MemoryAccessor instance.
and(MemberSelector...) - Static method in class com.hazelcast.cluster.memberselector.MemberSelectors
Selects a member when all of the selectors succeed
and(BiPredicateEx<? super T, ? super U>) - Method in interface com.hazelcast.internal.util.function.BiPredicateEx
and(PredicateEx<? super T>) - Method in interface com.hazelcast.internal.util.function.PredicateEx
and(Predicate) - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
and(Predicate) - Method in interface com.hazelcast.query.PredicateBuilder
 
and(Predicate...) - Static method in class com.hazelcast.query.Predicates
Creates an and predicate that will perform the logical and operation on the given predicates.
AND_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
AndFilter<T> - Class in com.hazelcast.internal.util.filter
Filter matching only when both sub-filters are matching
AndFilter(Filter<T>, Filter<T>) - Constructor for class com.hazelcast.internal.util.filter.AndFilter
 
AndMemberSelector - Class in com.hazelcast.cluster.memberselector.impl
Selects a member only if all of the sub-selectors succeed
AndMemberSelector(MemberSelector...) - Constructor for class com.hazelcast.cluster.memberselector.impl.AndMemberSelector
 
AndPredicate - Class in com.hazelcast.query.impl.predicates
And Predicate
AndPredicate() - Constructor for class com.hazelcast.query.impl.predicates.AndPredicate
 
AndPredicate(Predicate...) - Constructor for class com.hazelcast.query.impl.predicates.AndPredicate
 
AndResultSet - Class in com.hazelcast.query.impl
And Result set for Predicates.
AndResultSet(Set<QueryableEntry>, List<Set<QueryableEntry>>, List<Predicate>) - Constructor for class com.hazelcast.query.impl.AndResultSet
 
andThen(BiConsumerEx<? super T, ? super U>) - Method in interface com.hazelcast.internal.util.function.BiConsumerEx
andThen(FunctionEx<? super R, ? extends V>) - Method in interface com.hazelcast.internal.util.function.BiFunctionEx
andThen(ConsumerEx<? super T>) - Method in interface com.hazelcast.internal.util.function.ConsumerEx
andThen(FunctionEx<? super R, ? extends V>) - Method in interface com.hazelcast.internal.util.function.FunctionEx
annotate(Object) - Method in class com.hazelcast.query.impl.getters.AbstractJsonGetter
 
annotate(Object) - Method in class com.hazelcast.query.impl.getters.JsonDataGetter
 
annotate(Object) - Method in class com.hazelcast.query.impl.getters.JsonGetter
 
answerWhoisMasterQuestion(JoinMessage, Connection) - Method in class com.hazelcast.internal.cluster.impl.ClusterJoinManager
Respond to a WhoisMasterOp.
any() - Static method in class com.hazelcast.client.impl.ClientSelectors
 
ANY_THREAD - Static variable in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
append(T[], T[]) - Static method in class com.hazelcast.internal.util.collection.ArrayUtils
Appends 2 arrays.
APPEND_FAILURE_RESPONSE - Static variable in class com.hazelcast.cp.internal.raft.impl.RaftDataSerializerHook
 
APPEND_FAILURE_RESPONSE_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
APPEND_REQUEST - Static variable in class com.hazelcast.cp.internal.raft.impl.RaftDataSerializerHook
 
APPEND_REQUEST_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
APPEND_SUCCESS_RESPONSE - Static variable in class com.hazelcast.cp.internal.raft.impl.RaftDataSerializerHook
 
APPEND_SUCCESS_RESPONSE_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
appendChild(Node) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
appendEntries(LogEntry...) - Method in class com.hazelcast.cp.internal.raft.impl.log.RaftLog
Appends new entries to the Raft log.
AppendFailureResponse - Class in com.hazelcast.cp.internal.raft.impl.dto
Struct for failure response to AppendEntries RPC.
AppendFailureResponse() - Constructor for class com.hazelcast.cp.internal.raft.impl.dto.AppendFailureResponse
 
AppendFailureResponse(RaftEndpoint, int, long) - Constructor for class com.hazelcast.cp.internal.raft.impl.dto.AppendFailureResponse
 
AppendFailureResponseHandlerTask - Class in com.hazelcast.cp.internal.raft.impl.handler
Handles AppendFailureResponse sent by AppendRequestHandlerTask after an append-entries request or InstallSnapshotHandlerTask after an install snapshot request.
AppendFailureResponseHandlerTask(RaftNodeImpl, AppendFailureResponse) - Constructor for class com.hazelcast.cp.internal.raft.impl.handler.AppendFailureResponseHandlerTask
 
AppendFailureResponseOp - Class in com.hazelcast.cp.internal.operation.integration
Carries a failure response from a Raft follower to a Raft leader for a AppendRequest RPC
AppendFailureResponseOp() - Constructor for class com.hazelcast.cp.internal.operation.integration.AppendFailureResponseOp
 
AppendFailureResponseOp(CPGroupId, AppendFailureResponse) - Constructor for class com.hazelcast.cp.internal.operation.integration.AppendFailureResponseOp
 
appendLabels(Set<String>) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
appendProperties(Properties) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
appendProperties(Map<String, ? extends Comparable>) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
AppendRequest - Class in com.hazelcast.cp.internal.raft.impl.dto
Struct for AppendEntries RPC.
AppendRequest() - Constructor for class com.hazelcast.cp.internal.raft.impl.dto.AppendRequest
 
AppendRequest(RaftEndpoint, int, int, long, long, LogEntry[], long) - Constructor for class com.hazelcast.cp.internal.raft.impl.dto.AppendRequest
 
appendRequestAckReceived() - Method in class com.hazelcast.cp.internal.raft.impl.state.FollowerState
Clears the flag for the append request backoff and updates the timestamp of append entries response
appendRequestAckTimestamp() - Method in class com.hazelcast.cp.internal.raft.impl.state.FollowerState
Returns timestamp of the last append entries response
AppendRequestHandlerTask - Class in com.hazelcast.cp.internal.raft.impl.handler
Handles AppendRequest sent by the leader.
AppendRequestHandlerTask(RaftNodeImpl, AppendRequest) - Constructor for class com.hazelcast.cp.internal.raft.impl.handler.AppendRequestHandlerTask
 
AppendRequestOp - Class in com.hazelcast.cp.internal.operation.integration
Carries a AppendRequest RPC from a Raft group leader to a follower
AppendRequestOp() - Constructor for class com.hazelcast.cp.internal.operation.integration.AppendRequestOp
 
AppendRequestOp(CPGroupId, AppendRequest) - Constructor for class com.hazelcast.cp.internal.operation.integration.AppendRequestOp
 
AppendSuccessResponse - Class in com.hazelcast.cp.internal.raft.impl.dto
Struct for successful response to AppendEntries RPC.
AppendSuccessResponse() - Constructor for class com.hazelcast.cp.internal.raft.impl.dto.AppendSuccessResponse
 
AppendSuccessResponse(RaftEndpoint, int, long, long) - Constructor for class com.hazelcast.cp.internal.raft.impl.dto.AppendSuccessResponse
 
AppendSuccessResponseHandlerTask - Class in com.hazelcast.cp.internal.raft.impl.handler
Handles AppendSuccessResponse sent by AppendRequestHandlerTask after an append-entries request or InstallSnapshotHandlerTask after an install snapshot request.
AppendSuccessResponseHandlerTask(RaftNodeImpl, AppendSuccessResponse) - Constructor for class com.hazelcast.cp.internal.raft.impl.handler.AppendSuccessResponseHandlerTask
 
AppendSuccessResponseOp - Class in com.hazelcast.cp.internal.operation.integration
Carries a success response from a Raft follower to a Raft leader for a AppendRequest RPC
AppendSuccessResponseOp() - Constructor for class com.hazelcast.cp.internal.operation.integration.AppendSuccessResponseOp
 
AppendSuccessResponseOp(CPGroupId, AppendSuccessResponse) - Constructor for class com.hazelcast.cp.internal.operation.integration.AppendSuccessResponseOp
 
appendToken(StringBuilder, StringBuilder) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
APPLICATION_VALIDATION_TOKEN - Static variable in class com.hazelcast.spi.properties.GroupProperty
Use this property to verify that Hazelcast nodes only join the cluster when their 'application' level configuration is the same.
apply(IFunction<Long, R>) - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
apply(IFunction<T, R>) - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
apply(T) - Method in interface com.hazelcast.core.IFunction
 
apply(IFunction<Long, R>) - Method in interface com.hazelcast.cp.IAtomicLong
Applies a function on the value, the actual stored value will not change.
apply(IFunction<E, R>) - Method in interface com.hazelcast.cp.IAtomicReference
Applies a function on the value, the actual stored value will not change.
apply(IFunction<Long, R>) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
apply(IFunction<T, R>) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
apply(IFunction<Long, R>) - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
apply(IFunction<Long, R>) - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
apply(K) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore.ReserveForUpdateFunction
 
apply(T, U) - Method in interface com.hazelcast.internal.util.function.BiFunctionEx
 
apply(T, T) - Method in interface com.hazelcast.internal.util.function.BinaryOperatorEx
 
apply(T) - Method in interface com.hazelcast.internal.util.function.FunctionEx
 
apply(Map.Entry) - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
apply(Map.Entry<K, V>) - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.AndPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.CompositeEqualPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.CompositeRangePredicate
 
apply(Map.Entry<K, V>) - Method in class com.hazelcast.query.impl.predicates.FalsePredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.InstanceOfPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.NotEqualPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.NotPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.OrPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
Used for delegating filtering to inner predicate.
apply(Map.Entry<K, V>) - Method in class com.hazelcast.query.impl.predicates.PartitionPredicateImpl
 
apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.SkipIndexPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.SqlPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.TruePredicate
 
apply(Map.Entry<K, V>) - Method in interface com.hazelcast.query.Predicate
Applies this predicate to the given map entry.
apply(Collection<Member>) - Method in class com.hazelcast.splitbrainprotection.impl.ProbabilisticSplitBrainProtectionFunction
 
apply(Collection<Member>) - Method in class com.hazelcast.splitbrainprotection.impl.RecentlyActiveSplitBrainProtectionFunction
 
apply(Collection<Member>) - Method in interface com.hazelcast.splitbrainprotection.SplitBrainProtectionFunction
Determines whether the minimum cluster size property is satisfied based on the current list of members in the cluster.
APPLY_OP - Static variable in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongDataSerializerHook
 
APPLY_OP - Static variable in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefDataSerializerHook
 
applyAsDouble(T) - Method in interface com.hazelcast.internal.util.function.ToDoubleFunctionEx
 
applyAsDoubleEx(T) - Method in interface com.hazelcast.internal.util.function.ToDoubleFunctionEx
Exception-declaring version of ToDoubleFunction.applyAsDouble(T).
applyAsInt(T) - Method in interface com.hazelcast.internal.util.function.ToIntFunctionEx
 
applyAsIntEx(T) - Method in interface com.hazelcast.internal.util.function.ToIntFunctionEx
Exception-declaring version of ToIntFunction.applyAsInt(T).
applyAsLong(T) - Method in interface com.hazelcast.internal.util.function.ToLongFunctionEx
 
applyAsLongEx(T) - Method in interface com.hazelcast.internal.util.function.ToLongFunctionEx
Exception-declaring version of ToLongFunction.applyAsLong(T).
applyAsync(IFunction<Long, R>) - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
applyAsync(IFunction<T, R>) - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
applyAsync(IFunction<Long, R>) - Method in interface com.hazelcast.cp.IAtomicLong
Applies a function on the value, the actual stored value will not change.
applyAsync(IFunction<E, R>) - Method in interface com.hazelcast.cp.IAtomicReference
Applies a function on the value, the actual stored value will not change.
applyAsync(IFunction<Long, R>) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
applyAsync(IFunction<T, R>) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
applyAsync(IFunction<Long, R>) - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
applyAsync(IFunction<Long, R>) - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
applyChanges() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
Provides a similar functionality as committing a transaction.
applyCompletedMigrations(Collection<MigrationInfo>, Address) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
applyEx(T, U) - Method in interface com.hazelcast.internal.util.function.BiFunctionEx
Exception-declaring version of BiFunction.apply(T, U).
applyEx(T, T) - Method in interface com.hazelcast.internal.util.function.BinaryOperatorEx
Exception-declaring version of BiFunction.apply(T, U).
applyEx(T) - Method in interface com.hazelcast.internal.util.function.FunctionEx
Exception-declaring version of Function.apply(T).
applyForSingleAttributeValue(Comparable) - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
 
applyForSingleAttributeValue(Comparable) - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
 
applyForSingleAttributeValue(Comparable) - Method in class com.hazelcast.query.impl.predicates.BoundedRangePredicate
 
applyForSingleAttributeValue(Comparable) - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
 
applyForSingleAttributeValue(Comparable) - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
 
applyForSingleAttributeValue(Comparable) - Method in class com.hazelcast.query.impl.predicates.InPredicate
 
applyForSingleAttributeValue(Comparable) - Method in class com.hazelcast.query.impl.predicates.LikePredicate
 
applyForSingleAttributeValue(Comparable) - Method in class com.hazelcast.query.impl.predicates.NotEqualPredicate
 
applyForSingleAttributeValue(Comparable) - Method in class com.hazelcast.query.impl.predicates.RegexPredicate
 
applyIfAbsent(K, Function<? super K, ? extends V>) - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
applyIfAbsent(K, Function<? super K, ? extends V>) - Method in interface com.hazelcast.internal.util.IConcurrentMap
applyIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
 
applyIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.hazelcast.internal.util.IConcurrentMap
applyLogEntries() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Applies committed log entries between lastApplied and commitIndex, if there's any available.
ApplyMessageTask - Class in com.hazelcast.cp.internal.datastructures.atomiclong.client
Client message task for ApplyOp
ApplyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.client.ApplyMessageTask
 
ApplyMessageTask - Class in com.hazelcast.cp.internal.datastructures.atomicref.client
Client message task for ApplyOp
ApplyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.client.ApplyMessageTask
 
ApplyNode(CompletableFuture<R>, Function<V, R>) - Constructor for class com.hazelcast.spi.impl.AbstractInvocationFuture.ApplyNode
 
ApplyOp<R> - Class in com.hazelcast.cp.internal.datastructures.atomiclong.operation
ApplyOp() - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.operation.ApplyOp
 
ApplyOp(String, IFunction<Long, R>) - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.operation.ApplyOp
 
ApplyOp - Class in com.hazelcast.cp.internal.datastructures.atomicref.operation
ApplyOp() - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.operation.ApplyOp
 
ApplyOp(String, Data, ApplyOp.ReturnValueType, boolean) - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.operation.ApplyOp
 
ApplyOp.ReturnValueType - Enum in com.hazelcast.cp.internal.datastructures.atomicref.operation
Used for specifying return value of the operation
applyRecordInfo(Record, RecordInfo) - Static method in class com.hazelcast.map.impl.record.Records
 
applySelector(ClientSelector) - Method in interface com.hazelcast.client.impl.ClientEngine
Only Clients that can pass through filter are allowed to connect to cluster.
applySelector(ClientSelector) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
applySelector(ClientSelector) - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
applyState() - Method in class com.hazelcast.cache.impl.operation.CacheNearCacheStateHolder
 
applyToEither(CompletionStage<? extends V>, Function<? super V, U>) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
applyToEither(CompletionStage<? extends V>, Function<? super V, U>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
applyToEither(CompletionStage<? extends V>, Function<? super V, U>) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
applyToEither(CompletionStage<? extends V>, Function<? super V, U>) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
applyToEitherAsync(CompletionStage<? extends V>, Function<? super V, U>) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
applyToEitherAsync(CompletionStage<? extends V>, Function<? super V, U>, Executor) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
applyToEitherAsync(CompletionStage<? extends ClientMessage>, Function<? super ClientMessage, U>, Executor) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
applyToEitherAsync(CompletionStage<? extends V>, Function<? super V, U>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
applyToEitherAsync(CompletionStage<? extends V>, Function<? super V, U>, Executor) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
applyToEitherAsync(CompletionStage<? extends V>, Function<? super V, U>) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
applyToEitherAsync(CompletionStage<? extends V>, Function<? super V, U>, Executor) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
applyToEitherAsync(CompletionStage<? extends V>, Function<? super V, U>) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
applyToEitherAsync(CompletionStage<? extends V>, Function<? super V, U>, Executor) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
applyUnsafeModeState(int, UnsafeModePartitionState) - Method in class com.hazelcast.cp.internal.RaftService
 
areMigrationTasksAllowed() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
ArgumentParser<I,O> - Interface in com.hazelcast.query.extractor
Common superclass for all argument parsers.
arguments - Variable in class com.hazelcast.client.impl.protocol.codec.CacheEntryProcessorCodec.RequestParameters
additional arguments to pass to the EntryProcessor
arrange(Collection<MemberGroup>, InternalPartition[]) - Method in interface com.hazelcast.internal.partition.PartitionStateGenerator
Arranges the partition layout.
arrange(Collection<MemberGroup>, InternalPartition[], Collection<Integer>) - Method in interface com.hazelcast.internal.partition.PartitionStateGenerator
Arranges the partition layout.
array() - Static method in class com.hazelcast.internal.json.Json
Creates a new empty JsonArray.
array(int...) - Static method in class com.hazelcast.internal.json.Json
Creates a new JsonArray that contains the JSON representations of the given int values.
array(long...) - Static method in class com.hazelcast.internal.json.Json
Creates a new JsonArray that contains the JSON representations of the given long values.
array(float...) - Static method in class com.hazelcast.internal.json.Json
Creates a new JsonArray that contains the JSON representations of the given float values.
array(double...) - Static method in class com.hazelcast.internal.json.Json
Creates a new JsonArray that contains the JSON representations of the given double values.
array(boolean...) - Static method in class com.hazelcast.internal.json.Json
Creates a new JsonArray that contains the JSON representations of the given boolean values.
array(String...) - Static method in class com.hazelcast.internal.json.Json
Creates a new JsonArray that contains the JSON representations of the given strings.
ARRAY_BOOLEAN_BASE_OFFSET - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Base offset of boolean[]
ARRAY_BOOLEAN_INDEX_SCALE - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Index scale of boolean[]
ARRAY_BYTE_BASE_OFFSET - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Base offset of byte[]
ARRAY_BYTE_INDEX_SCALE - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Index scale of byte[]
ARRAY_CHAR_BASE_OFFSET - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Base offset of char[]
ARRAY_CHAR_INDEX_SCALE - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Index scale of char[]
ARRAY_DOUBLE_BASE_OFFSET - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Base offset of double[]
ARRAY_DOUBLE_INDEX_SCALE - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Index scale of double[]
ARRAY_FLOAT_BASE_OFFSET - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Base offset of float[]
ARRAY_FLOAT_INDEX_SCALE - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Index scale of float[]
ARRAY_INDEX_OUT_OF_BOUNDS - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
ARRAY_INT_BASE_OFFSET - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Base offset of int[]
ARRAY_INT_INDEX_SCALE - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Index scale of int[]
ARRAY_LONG_BASE_OFFSET - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Base offset of long[]
ARRAY_LONG_INDEX_SCALE - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Index scale of long[]
ARRAY_OBJECT_BASE_OFFSET - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Base offset of any type of Object[]
ARRAY_OBJECT_INDEX_SCALE - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Index scale of any type of Object[]
ARRAY_SHORT_BASE_OFFSET - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Base offset of short[]
ARRAY_SHORT_INDEX_SCALE - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Index scale of short[]
ARRAY_STORE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
arrayBaseOffset(Class<?>) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Gets the base offset of the array typed with given class.
arrayBaseOffset(Class<?>) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
arrayBaseOffset(Class<?>) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
ArrayBlockingQueueStreamSerializer<E> - Class in com.hazelcast.internal.serialization.impl
The ArrayBlockingQueue serializer Important Note: The `fair` boolean is not be serialized since there is no public way to access it.
ArrayBlockingQueueStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ArrayBlockingQueueStreamSerializer
 
ArrayDataSerializableFactory - Class in com.hazelcast.internal.serialization.impl
 
ArrayDataSerializableFactory(ConstructorFunction<Integer, IdentifiedDataSerializable>[]) - Constructor for class com.hazelcast.internal.serialization.impl.ArrayDataSerializableFactory
 
ArrayDequeStreamSerializer<E> - Class in com.hazelcast.internal.serialization.impl
The ArrayDeque serializer
ArrayDequeStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ArrayDequeStreamSerializer
 
arrayIndexScale(Class<?>) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Gets the index scale of the array typed with given class.
arrayIndexScale(Class<?>) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
arrayIndexScale(Class<?>) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
ArrayListStreamSerializer<E> - Class in com.hazelcast.internal.serialization.impl
The ArrayList serializer
ArrayListStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ArrayListStreamSerializer
 
ArrayMerkleTree - Class in com.hazelcast.wan.impl.merkletree
A not thread-safe, array based MerkleTree implementation, which represents each node of the tree as a single int containing the node's hash.
ArrayMerkleTree(int) - Constructor for class com.hazelcast.wan.impl.merkletree.ArrayMerkleTree
 
ArrayRingbuffer<E> - Class in com.hazelcast.ringbuffer.impl
The ArrayRingbuffer is responsible for storing the actual contents of a ringbuffer.
ArrayRingbuffer(int) - Constructor for class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
 
ArrayStreamSerializer - Class in com.hazelcast.internal.serialization.impl
The Object[] serializer
ArrayStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ArrayStreamSerializer
 
ArrayUtils - Class in com.hazelcast.internal.util.collection
Convenient method for array manipulations.
asArray() - Method in class com.hazelcast.internal.json.JsonArray
 
asArray() - Method in class com.hazelcast.internal.json.JsonValue
Returns this JSON value as JsonArray, assuming that this value represents a JSON array.
asBoolean() - Method in class com.hazelcast.internal.json.JsonValue
Returns this JSON value as a boolean value, assuming that this value is either true or false.
asCacheConfig(CacheConfig) - Static method in class com.hazelcast.cache.impl.PreJoinCacheConfig
 
asCacheConfig(SerializationService) - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
asCompletableFuture(Future<V>) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
asCompletableFuture(Future<V>) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
asCredentialsFactory(ClassLoader) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
asCredentialsFactory(ClassLoader) - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
asCredentialsFactory(ClassLoader) - Method in class com.hazelcast.config.security.CredentialsIdentityConfig
 
asCredentialsFactory(ClassLoader) - Method in interface com.hazelcast.config.security.IdentityConfig
Converts current configuration to a ICredentialsFactory instance.
asCredentialsFactory() - Method in class com.hazelcast.config.security.RealmConfig
 
asCredentialsFactory(ClassLoader) - Method in class com.hazelcast.config.security.TokenIdentityConfig
 
asCredentialsFactory(ClassLoader) - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
 
asData() - Method in interface com.hazelcast.security.TokenCredentials
Returns the token represented as Data.
asDouble() - Method in class com.hazelcast.internal.json.JsonValue
Returns this JSON value as a double value, assuming that this value represents a JSON number.
asDoubleExactly(Number) - Static method in class com.hazelcast.query.impl.Numbers
Represents the given Number exactly as a double value without any magnitude and precision losses; if that's not possible, fails by throwing an exception.
asElementIterable(NodeList) - Static method in class com.hazelcast.config.DomConfigHelper
 
asEvictionConfg(SerializationService) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.EvictionConfigHolder
 
asFloat() - Method in class com.hazelcast.internal.json.JsonValue
Returns this JSON value as a float value, assuming that this value represents a JSON number.
asInt() - Method in class com.hazelcast.internal.json.JsonValue
Returns this JSON value as an int value, assuming that this value represents a JSON number that can be interpreted as Java int.
asIntegerList(int[]) - Static method in class com.hazelcast.internal.util.CollectionUtil
Adapts an int array to an Integer List.
asIntExactly(Number) - Static method in class com.hazelcast.query.impl.Numbers
Represents the given Number exactly as an int value without any magnitude and precision losses; if that's not possible, fails by throwing an exception.
asList() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
Returns a read-only list representation of this queue.
asListenerConfig(SerializationService) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.ListenerConfigHolder
 
asLoginModuleConfigs() - Method in interface com.hazelcast.config.security.AuthenticationConfig
Converts current configuration to stack of login modules.
asLoginModuleConfigs() - Method in class com.hazelcast.config.security.DefaultAuthenticationConfig
 
asLoginModuleConfigs() - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
 
asLoginModuleConfigs() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
asLoginModuleConfigs() - Method in class com.hazelcast.config.security.RealmConfig
 
asLoginModuleConfigs() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
 
asLong() - Method in class com.hazelcast.internal.json.JsonValue
Returns this JSON value as a long value, assuming that this value represents a JSON number that can be interpreted as Java long.
asLongExactly(Number) - Static method in class com.hazelcast.query.impl.Numbers
Represents the given Number exactly as a long value without any magnitude and precision losses; if that's not possible, fails by throwing an exception.
asMapping(YamlNode) - Static method in class com.hazelcast.internal.yaml.YamlUtil
Takes a generic YamlNode instance and returns it casted to YamlMapping if the type of the node is a descendant of YamlMapping.
asMapStoreConfig(SerializationService) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
asNearCacheConfig(SerializationService) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.NearCacheConfigHolder
 
asObject() - Method in class com.hazelcast.internal.json.JsonObject
 
asObject() - Method in class com.hazelcast.internal.json.JsonValue
Returns this JSON value as JsonObject, assuming that this value represents a JSON object.
asPassThroughSet(Set<DeferredValue<V>>, SerializationService) - Static method in class com.hazelcast.cache.impl.DeferredValue
Adapts a Set<DeferredValue<V>> as a Set<V>.
asPredicateConfig(SerializationService) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.PredicateConfigHolder
 
asQueryCacheConfig(SerializationService) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
asQueueStoreConfig(SerializationService) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueueStoreConfigHolder
 
asRingbufferStoreConfig(SerializationService) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.RingbufferStoreConfigHolder
 
asScalar(YamlNode) - Static method in class com.hazelcast.internal.yaml.YamlUtil
Takes a generic YamlNode instance and returns it casted to YamlScalar if the type of the node is a descendant of YamlScalar.
asSequence(YamlNode) - Static method in class com.hazelcast.internal.yaml.YamlUtil
Takes a generic YamlNode instance and returns it casted to YamlSequence if the type of the node is a descendant of YamlSequence.
ASSERTION_ERROR - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
assertRunningOnPartitionThread() - Static method in class com.hazelcast.internal.util.ThreadUtil
 
assertValid() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
ASSIGN_PARTITIONS - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
AssignPartitions - Class in com.hazelcast.internal.partition.operation
Sent from non-master nodes to the master to initialize the partition assignment.
AssignPartitions() - Constructor for class com.hazelcast.internal.partition.operation.AssignPartitions
 
asString() - Method in class com.hazelcast.internal.json.JsonValue
Returns this JSON value as String, assuming that this value represents a JSON string.
asType(YamlNode, Class<T>) - Static method in class com.hazelcast.internal.yaml.YamlUtil
Takes a generic YamlNode instance and returns it casted to the provided type if the node is an instance of that type.
asVersion() - Method in class com.hazelcast.version.MemberVersion
 
asW3cNode(YamlNode) - Static method in class com.hazelcast.internal.config.yaml.W3cDomUtil
Returns an adapted W3C Node view of the provided YamlNode
ASYNC_EXECUTOR - Static variable in interface com.hazelcast.spi.impl.executionservice.ExecutionService
Name of the async executor.
ASYNC_RESULT_WAIT_TIMEOUT_MINUTES - Static variable in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationMetaDataFetcher
 
asyncBackupCount - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
number of asynchronous backups
asyncBackupCount - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCardinalityEstimatorConfigCodec.RequestParameters
number of asynchronous backups
asyncBackupCount - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddListConfigCodec.RequestParameters
number of asynchronous backups
asyncBackupCount - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
number of asynchronous backups
asyncBackupCount - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMultiMapConfigCodec.RequestParameters
number of asynchronous backups
asyncBackupCount - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddQueueConfigCodec.RequestParameters
number of asynchronous backups
asyncBackupCount - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddRingbufferConfigCodec.RequestParameters
number of asynchronous backups
asyncBackupCount - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddSetConfigCodec.RequestParameters
number of asynchronous backups
AsyncConsoleRequest - Interface in com.hazelcast.internal.management.request
Represents async requests sent from Management Center.
asyncFillup - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReplicatedMapConfigCodec.RequestParameters
true to make the replicated map available for reads before initial replication is completed, false otherwise.
AsyncRaftOp - Class in com.hazelcast.cp.internal.operation.integration
Base class for operation classes that will carry Raft RPCs between Raft nodes
ATOMIC_LONG_MERGING_VALUE - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
ATOMIC_LONG_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ATOMIC_LONG_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ATOMIC_REFERENCE_MERGING_VALUE - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
ATOMIC_REFERENCE_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ATOMIC_REFERENCE_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
AtomicLong - Class in com.hazelcast.cp.internal.datastructures.atomiclong
State-machine implementation of the Raft-based atomic long
AtomicLongAddAndGetCodec - Class in com.hazelcast.client.impl.protocol.codec
Atomically adds the given value to the current value.
AtomicLongAddAndGetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicLongAddAndGetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicLongAlterCodec - Class in com.hazelcast.client.impl.protocol.codec
Alters the currently stored value by applying a function on it.
AtomicLongAlterCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicLongAlterCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicLongApplyCodec - Class in com.hazelcast.client.impl.protocol.codec
Applies a function on the value, the actual stored value will not change
AtomicLongApplyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicLongApplyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicLongCompareAndSetCodec - Class in com.hazelcast.client.impl.protocol.codec
Atomically sets the value to the given updated value only if the current value the expected value.
AtomicLongCompareAndSetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicLongCompareAndSetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicLongDataSerializerHook - Class in com.hazelcast.cp.internal.datastructures.atomiclong
 
AtomicLongDataSerializerHook() - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongDataSerializerHook
 
AtomicLongGetAndAddCodec - Class in com.hazelcast.client.impl.protocol.codec
Atomically adds the given value to the current value.
AtomicLongGetAndAddCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicLongGetAndAddCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicLongGetAndSetCodec - Class in com.hazelcast.client.impl.protocol.codec
Atomically sets the given value and returns the old value.
AtomicLongGetAndSetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicLongGetAndSetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicLongGetCodec - Class in com.hazelcast.client.impl.protocol.codec
Gets the current value.
AtomicLongGetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicLongGetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicLongMBean - Class in com.hazelcast.internal.jmx
Management bean for IAtomicLong
AtomicLongMBean(IAtomicLong, ManagementService) - Constructor for class com.hazelcast.internal.jmx.AtomicLongMBean
 
AtomicLongMergingValueImpl - Class in com.hazelcast.spi.impl.merge
AtomicLongMergingValueImpl() - Constructor for class com.hazelcast.spi.impl.merge.AtomicLongMergingValueImpl
 
AtomicLongMergingValueImpl(SerializationService) - Constructor for class com.hazelcast.spi.impl.merge.AtomicLongMergingValueImpl
 
AtomicLongPermission - Class in com.hazelcast.security.permission
 
AtomicLongPermission(String, String...) - Constructor for class com.hazelcast.security.permission.AtomicLongPermission
 
AtomicLongProxy - Class in com.hazelcast.client.cp.internal.datastructures.atomiclong
Client-side Raft-based proxy implementation of IAtomicLong
AtomicLongProxy(ClientContext, RaftGroupId, String, String) - Constructor for class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
AtomicLongProxy - Class in com.hazelcast.cp.internal.datastructures.atomiclong.proxy
Server-side Raft-based proxy implementation of IAtomicLong
AtomicLongProxy(NodeEngine, RaftGroupId, String, String) - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
AtomicLongService - Class in com.hazelcast.cp.internal.datastructures.atomiclong
Contains Raft-based atomic long instances, implements snapshotting, and creates proxies
AtomicLongService(NodeEngine) - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongService
 
AtomicLongSnapshot - Class in com.hazelcast.cp.internal.datastructures.atomiclong
Snapshot of a AtomicLongService state for a Raft group
AtomicLongSnapshot() - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongSnapshot
 
AtomicLongSnapshot(Map<String, Long>, Set<String>) - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongSnapshot
 
AtomicRef - Class in com.hazelcast.cp.internal.datastructures.atomicref
State-machine implementation of the Raft-based atomic reference
AtomicRefApplyCodec - Class in com.hazelcast.client.impl.protocol.codec
Applies a function on the value
AtomicRefApplyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicRefApplyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicRefCompareAndSetCodec - Class in com.hazelcast.client.impl.protocol.codec
Alters the currently stored value by applying a function on it.
AtomicRefCompareAndSetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicRefCompareAndSetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicRefContainsCodec - Class in com.hazelcast.client.impl.protocol.codec
Checks if the reference contains the value.
AtomicRefContainsCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicRefContainsCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicRefDataSerializerHook - Class in com.hazelcast.cp.internal.datastructures.atomicref
 
AtomicRefDataSerializerHook() - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefDataSerializerHook
 
AtomicReferenceMBean - Class in com.hazelcast.internal.jmx
Management bean for IAtomicReference
AtomicReferenceMBean(IAtomicReference, ManagementService) - Constructor for class com.hazelcast.internal.jmx.AtomicReferenceMBean
 
AtomicReferenceMergingValueImpl - Class in com.hazelcast.spi.impl.merge
AtomicReferenceMergingValueImpl() - Constructor for class com.hazelcast.spi.impl.merge.AtomicReferenceMergingValueImpl
 
AtomicReferenceMergingValueImpl(SerializationService) - Constructor for class com.hazelcast.spi.impl.merge.AtomicReferenceMergingValueImpl
 
AtomicReferencePermission - Class in com.hazelcast.security.permission
 
AtomicReferencePermission(String, String...) - Constructor for class com.hazelcast.security.permission.AtomicReferencePermission
 
AtomicRefGetCodec - Class in com.hazelcast.client.impl.protocol.codec
Gets the current value.
AtomicRefGetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicRefGetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicRefProxy<T> - Class in com.hazelcast.client.cp.internal.datastructures.atomicref
Client-side Raft-based proxy implementation of IAtomicReference
AtomicRefProxy(ClientContext, RaftGroupId, String, String) - Constructor for class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
AtomicRefProxy<T> - Class in com.hazelcast.cp.internal.datastructures.atomicref.proxy
Server-side Raft-based proxy implementation of IAtomicReference
AtomicRefProxy(NodeEngine, RaftGroupId, String, String) - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
AtomicRefService - Class in com.hazelcast.cp.internal.datastructures.atomicref
Contains Raft-based atomic reference instances, implements snapshotting, and creates proxies
AtomicRefService(NodeEngine) - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefService
 
AtomicRefSetCodec - Class in com.hazelcast.client.impl.protocol.codec
Atomically sets the given value
AtomicRefSetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicRefSetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
AtomicRefSnapshot - Class in com.hazelcast.cp.internal.datastructures.atomicref
Snapshot of a AtomicRefService state for a Raft group
AtomicRefSnapshot() - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefSnapshot
 
AtomicRefSnapshot(Map<String, Data>, Set<String>) - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefSnapshot
 
AttributeConfig - Class in com.hazelcast.config
Contains the configuration of a custom attribute that will be extracted from a Map's entry using a given ValueExtractor.
AttributeConfig() - Constructor for class com.hazelcast.config.AttributeConfig
Creates an empty AttributeConfig.
AttributeConfig(String, String) - Constructor for class com.hazelcast.config.AttributeConfig
Creates a AttributeConfig with the given attribute and ordered setting.
AttributeConfig(AttributeConfig) - Constructor for class com.hazelcast.config.AttributeConfig
 
AttributeConfigCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
AttributeConfigReadOnly - Class in com.hazelcast.internal.config
Contains the configuration for a extractor of Map.
AttributeConfigReadOnly(AttributeConfig) - Constructor for class com.hazelcast.internal.config.AttributeConfigReadOnly
 
attributeConfigs - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
map attributes
AttributeIndexRegistry - Class in com.hazelcast.query.impl
Maintains a registry of single-attribute indexes.
AttributeIndexRegistry() - Constructor for class com.hazelcast.query.impl.AttributeIndexRegistry
 
attributeMap - Variable in class com.hazelcast.internal.jmx.HazelcastMBean
 
attributeMap() - Method in class com.hazelcast.internal.networking.AbstractChannel
 
attributeMap() - Method in interface com.hazelcast.internal.networking.Channel
Returns the attribute map.
attributePath - Variable in class com.hazelcast.aggregation.impl.AbstractAggregator
 
attributes - Variable in class com.hazelcast.cluster.impl.AbstractMember
 
attributes(Map<String, String>) - Method in class com.hazelcast.cluster.impl.MemberImpl.Builder
 
AttributeType - Enum in com.hazelcast.query.impl
Type of Attribute
AUDIT_LOG_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
AuditableEvent - Interface in com.hazelcast.internal.auditlog
Observable event in the system.
AuditlogService - Interface in com.hazelcast.internal.auditlog
Service for logging AuditableEvents.
AuditlogTypeIds - Class in com.hazelcast.internal.auditlog.impl
 
AUTH_FAILURE - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
authenticate(HttpPostCommand, String, String) - Method in class com.hazelcast.internal.ascii.rest.HttpPostCommandProcessor
Checks if the request is valid.
authenticated(UUID, Credentials, String, long, String, Set<String>) - Method in interface com.hazelcast.client.impl.ClientEndpoint
 
authenticated(UUID, Credentials, String, long, String, Set<String>) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
AUTHENTICATION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
AuthenticationBaseMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
Base authentication task
AuthenticationConfig - Interface in com.hazelcast.config.security
This interface represents authentication configuration in a security realm.
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
A HazelcastException that is thrown when there is an Authentication failure: e.g.
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.
AuthenticationFailureOp - Class in com.hazelcast.internal.cluster.impl.operations
 
AuthenticationFailureOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.AuthenticationFailureOp
 
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
 
AuthenticationStatus - Enum in com.hazelcast.client.impl.protocol
Status codes of authentication results
AutoBatcher - Class in com.hazelcast.flakeidgen.impl
A utility to serve IDs from IdBatch one by one, watching for validity.
AutoBatcher(int, long, AutoBatcher.IdBatchSupplier) - Constructor for class com.hazelcast.flakeidgen.impl.AutoBatcher
 
AutoBatcher.IdBatchSupplier - Interface in com.hazelcast.flakeidgen.impl
 
available() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
AVAILABLE_PERMITS_OP - Static variable in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreDataSerializerHook
 
availableCapacity() - Method in class com.hazelcast.cp.internal.raft.impl.log.RaftLog
Returns the number of empty indices in the Raft log
availableLogCapacity - Variable in class com.hazelcast.cp.internal.RaftNodeMetrics
 
availablePermits() - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionAwareSemaphoreProxy
 
availablePermits() - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionlessSemaphoreProxy
 
availablePermits() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionAwareSemaphoreProxy
 
availablePermits() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionlessSemaphoreProxy
 
availablePermits(CPGroupId, String) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreService
 
availablePermits() - Method in interface com.hazelcast.cp.ISemaphore
Returns the current number of permits currently available in this semaphore.
AvailablePermitsMessageTask - Class in com.hazelcast.cp.internal.datastructures.semaphore.client
Client message task for AvailablePermitsOp
AvailablePermitsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.client.AvailablePermitsMessageTask
 
AvailablePermitsOp - Class in com.hazelcast.cp.internal.datastructures.semaphore.operation
AvailablePermitsOp() - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.operation.AvailablePermitsOp
 
AvailablePermitsOp(String) - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.operation.AvailablePermitsOp
 
availableReplicaSyncPermits() - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
Returns the number of available permits.
await(long, TimeUnit) - Method in class com.hazelcast.client.cp.internal.datastructures.countdownlatch.CountDownLatchProxy
 
await(long, TimeUnit) - Method in interface com.hazelcast.cp.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(CPGroupId, String, AwaitInvocationKey, long) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchService
 
await(long, TimeUnit) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.proxy.CountDownLatchProxy
 
AWAIT_COMPLETION_TIMEOUT_SECONDS - Static variable in class com.hazelcast.cache.impl.CacheProxyUtil
 
AWAIT_INVOCATION_KEY - Static variable in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchDataSerializerHook
 
AWAIT_MAP_FLUSH - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
AWAIT_OP - Static variable in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchDataSerializerHook
 
awaitCompletion(long, TimeUnit) - Method in class com.hazelcast.internal.util.LocalRetryableExecution
Causes the current thread to wait until the operation has finished the thread is interrupted, or the specified waiting time elapses.
awaitConnected(long, TimeUnit) - Method in class com.hazelcast.client.util.ClientStateListener
Waits until the client is connected to cluster or the timeout expires.
awaitConnected() - Method in class com.hazelcast.client.util.ClientStateListener
Waits until the client is connected to cluster.
awaitDisconnected(long, TimeUnit) - Method in class com.hazelcast.client.util.ClientStateListener
Waits until the client is disconnected from the cluster or the timeout expires.
awaitDisconnected() - Method in class com.hazelcast.client.util.ClientStateListener
Waits until the client is disconnected from the cluster.
awaitDrainerGone() - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Blocks until the drainer thread leaves.
AwaitInvocationKey - Class in com.hazelcast.cp.internal.datastructures.countdownlatch
Represents a ICountDownLatch.await(long, TimeUnit)} invocation
AwaitInvocationKey(long, UUID, Address, long) - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.AwaitInvocationKey
 
awaitLatch(CountDownLatch, InternalCompletableFuture) - Method in class com.hazelcast.cache.impl.AbstractCacheSyncListenerCompleter
 
AwaitMapFlushOperation - Class in com.hazelcast.map.impl.operation
IMap.flush() call waits the end of flush by using this operation.
AwaitMapFlushOperation() - Constructor for class com.hazelcast.map.impl.operation.AwaitMapFlushOperation
 
AwaitMapFlushOperation(String, long) - Constructor for class com.hazelcast.map.impl.operation.AwaitMapFlushOperation
 
AwaitMessageTask - Class in com.hazelcast.cp.internal.datastructures.countdownlatch.client
Client message task for AwaitOp
AwaitMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.client.AwaitMessageTask
 
AwaitOp - Class in com.hazelcast.cp.internal.datastructures.countdownlatch.operation
AwaitOp() - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.AwaitOp
 
AwaitOp(String, UUID, long) - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.AwaitOp
 
awaitTermination(long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
awaitTermination(long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
awaitTermination(long, TimeUnit) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
awaitTermination(long, TimeUnit) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
awaitTermination(long, TimeUnit) - Method in class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
awaitTermination(int, TimeUnit) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationThread
 
awaitTermination(long) - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationMonitor
 
awaitUntilDiscoveryCompleted(long, TimeUnit) - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Blocks until the CP discovery process is completed, or the given timeout occurs, or the current thread is interrupted, whichever happens first.
awaitUntilDiscoveryCompleted(long, TimeUnit) - Method in class com.hazelcast.cp.internal.RaftService
 
AWS_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
AwsConfig - Class in com.hazelcast.config
The AWSConfig contains the configuration for AWS join mechanism.
AwsConfig() - Constructor for class com.hazelcast.config.AwsConfig
 
AwsConfig(AwsConfig) - Constructor for class com.hazelcast.config.AwsConfig
 
AZURE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
AzureConfig - Class in com.hazelcast.config
Configuration for the Azure Discovery Strategy.
AzureConfig() - Constructor for class com.hazelcast.config.AzureConfig
 
AzureConfig(AzureConfig) - Constructor for class com.hazelcast.config.AzureConfig
 

B

BackoffIdleStrategy - Class in com.hazelcast.internal.util.concurrent
Idling strategy for threads when they have no work to do.
BackoffIdleStrategy(long, long, long, long) - Constructor for class com.hazelcast.internal.util.concurrent.BackoffIdleStrategy
Create a set of state tracking idle behavior
BACKPRESSURE_BACKOFF_TIMEOUT_MILLIS - Static variable in class com.hazelcast.client.properties.ClientProperty
Control the maximum timeout in millis to wait for an invocation space to be available.
BACKPRESSURE_BACKOFF_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Control the maximum timeout in millis to wait for an invocation space to be available.
BACKPRESSURE_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Using back pressure, you can prevent an overload of pending asynchronous backups.
BACKPRESSURE_MAX_CONCURRENT_INVOCATIONS_PER_PARTITION - Static variable in class com.hazelcast.spi.properties.GroupProperty
The maximum number of concurrent invocations per partition.
BACKPRESSURE_SYNCWINDOW - Static variable in class com.hazelcast.spi.properties.GroupProperty
Controls the frequency of a BackupAwareOperation getting its async backups converted to a sync backups.
backpressureOff() - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Lowers the backpressure flag.
backpressureOn() - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Raises the backpressure flag, which will make the caller of submit to block until the flag is lowered.
backup() - Method in interface com.hazelcast.hotrestart.HotRestartService
Attempts to perform a cluster hot restart data backup.
backup(long) - Method in interface com.hazelcast.hotrestart.HotRestartService
Attempts to perform a cluster hot restart data backup.
backup() - Method in class com.hazelcast.internal.hotrestart.NoOpHotRestartService
 
backup(long) - Method in class com.hazelcast.internal.hotrestart.NoOpHotRestartService
 
Backup - Class in com.hazelcast.spi.impl.operationservice.impl.operations
 
Backup() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
 
Backup(Operation, Address, long[], boolean) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
 
Backup(Operation, Address, long[], boolean, long) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
 
Backup(Data, Address, long[], boolean) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
 
Backup(Data, Address, long[], boolean, long) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
 
BACKUP - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
BACKUP_ACK_RESPONSE - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
BACKUP_AWARE_FLAG - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
BACKUP_DIR_PREFIX - Static variable in interface com.hazelcast.hotrestart.HotRestartService
The prefix for each hot restart backup directory.
BACKUP_ENTRY_PROCESSOR - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
BACKUP_EVENT_FLAG - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
BACKUP_RESPONSE_SIZE_IN_BYTES - Static variable in class com.hazelcast.spi.impl.operationservice.impl.responses.BackupAckResponse
 
BackupAckResponse - Class in com.hazelcast.spi.impl.operationservice.impl.responses
The {Response} for a BackupOperation.
BackupAckResponse() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.BackupAckResponse
 
BackupAckResponse(long, boolean) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.BackupAckResponse
 
BackupAwareEntryProcessor<K,V,T> - Interface in com.hazelcast.cache
An invocable function that allows applications to perform compound operations on a Cache.Entry atomically, according to the defined consistency of a Cache.
BackupAwareOperation - Interface in com.hazelcast.spi.impl.operationservice
A BackupAwareOperation is an Operation to indicate then when a change is made, a BackupOperation is created to replicate the backup.
backupCount - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
number of synchronous backups
backupCount - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCardinalityEstimatorConfigCodec.RequestParameters
number of synchronous backups
backupCount - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddListConfigCodec.RequestParameters
number of synchronous backups
backupCount - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
number of synchronous backups
backupCount - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMultiMapConfigCodec.RequestParameters
number of synchronous backups
backupCount - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddQueueConfigCodec.RequestParameters
number of synchronous backups
backupCount - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddRingbufferConfigCodec.RequestParameters
number of synchronous backups
backupCount - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddSetConfigCodec.RequestParameters
number of synchronous backups
BackupEventHandler() - Constructor for class com.hazelcast.client.impl.spi.impl.SmartClientInvocationService.BackupEventHandler
 
backupHandler() - Method in class com.hazelcast.spi.impl.operationservice.impl.InboundResponseHandlerSupplier
 
BackupOperation - Interface in com.hazelcast.spi.impl.operationservice
When an BackupAwareOperation makes a change, the backups need to be replicated to other members (depending on the configuration and if change really happened).
backupRecord - Variable in class com.hazelcast.cache.impl.operation.KeyBasedCacheOperation
 
backupsAcksReceived - Variable in class com.hazelcast.spi.impl.operationservice.impl.BaseInvocation
Number of backups acks received.
backupSize() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Returns the number of queue items contained on this backup replica.
BackupTaskState - Enum in com.hazelcast.hotrestart
The state of the hot restart backup task
BackupTaskStatus - Class in com.hazelcast.hotrestart
The status of the hot restart backup task, including progress and state.
BackupTaskStatus(BackupTaskState, int, int) - Constructor for class com.hazelcast.hotrestart.BackupTaskStatus
 
balancerIntervalSeconds(int) - Method in class com.hazelcast.internal.networking.nio.NioNetworking.Context
 
base - Variable in class com.hazelcast.client.impl.protocol.codec.FlakeIdGeneratorNewIdBatchCodec.ResponseParameters
TODO DOC
base() - Method in class com.hazelcast.flakeidgen.impl.IdBatch
Returns the first ID in the set.
baseAddress - Variable in class com.hazelcast.internal.util.sort.MemArrayQuickSorter
 
BaseHeapNearCacheRecordStore<K,V,R extends NearCacheRecord> - Class in com.hazelcast.internal.nearcache.impl.store
Base implementation of AbstractNearCacheRecordStore for on-heap Near Caches.
BaseIndexStore - Class in com.hazelcast.query.impl
Base class for concrete index store implementations
BaseInvocation - Class in com.hazelcast.spi.impl.operationservice.impl
BaseInvocation for client and core.
BaseInvocation() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.BaseInvocation
 
BaseMap<K,V> - Interface in com.hazelcast.map
Base interface for Hazelcast distributed maps.
BaseMultiMap<K,V> - Interface in com.hazelcast.multimap
Base interface for Hazelcast distributed multi-maps.
BasePutOperation - Class in com.hazelcast.map.impl.operation
 
BasePutOperation(String, Data, Data) - Constructor for class com.hazelcast.map.impl.operation.BasePutOperation
 
BasePutOperation() - Constructor for class com.hazelcast.map.impl.operation.BasePutOperation
 
BaseQueue<E> - Interface in com.hazelcast.collection
Base interface for Hazelcast distributed queues.
BaseRemoveOperation - Class in com.hazelcast.map.impl.operation
 
BaseRemoveOperation() - Constructor for class com.hazelcast.map.impl.operation.BaseRemoveOperation
 
BaseRemoveOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.BaseRemoveOperation
 
BaseTxnQueueOperation - Class in com.hazelcast.collection.impl.txnqueue.operations
 
BaseTxnQueueOperation() - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.BaseTxnQueueOperation
 
BaseTxnQueueOperation(String, long) - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.BaseTxnQueueOperation
 
BaseTypeConverter() - Constructor for class com.hazelcast.query.impl.TypeConverters.BaseTypeConverter
 
BasicAccumulator<E extends Sequenced> - Class in com.hazelcast.map.impl.querycache.accumulator
This class implements basic functionality of an Accumulator.
BasicAccumulator(QueryCacheContext, AccumulatorInfo) - Constructor for class com.hazelcast.map.impl.querycache.accumulator.BasicAccumulator
 
BasicSSLContextFactory - Class in com.hazelcast.nio.ssl
Empty implementation.
BasicSSLContextFactory() - Constructor for class com.hazelcast.nio.ssl.BasicSSLContextFactory
 
batch - Variable in class com.hazelcast.client.impl.protocol.codec.CacheIterateCodec.RequestParameters
The number of items to be batched
batch - Variable in class com.hazelcast.client.impl.protocol.codec.CacheIterateEntriesCodec.RequestParameters
The number of items to be batched
batch - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchEntriesCodec.RequestParameters
The number of items to be batched
batch - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchKeysCodec.RequestParameters
The number of items to be batched
batch - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchWithQueryCodec.RequestParameters
The number of items to be batched
batchEvent - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
BatchEventData - Class in com.hazelcast.map.impl.querycache.event
Holder for a collection of QueryCacheEventData.
BatchEventData() - Constructor for class com.hazelcast.map.impl.querycache.event.BatchEventData
 
BatchEventData(Collection<QueryCacheEventData>, String, int) - Constructor for class com.hazelcast.map.impl.querycache.event.BatchEventData
 
BatchIMapEvent - Class in com.hazelcast.map.impl.querycache.event
BatchIMapEvent(BatchEventData) - Constructor for class com.hazelcast.map.impl.querycache.event.BatchIMapEvent
 
BatchInvalidator - Class in com.hazelcast.internal.nearcache.impl.invalidation
Sends invalidations to Near Cache in batches.
BatchInvalidator(String, int, int, Function<EventRegistration, Boolean>, NodeEngine) - Constructor for class com.hazelcast.internal.nearcache.impl.invalidation.BatchInvalidator
 
BatchNearCacheInvalidation - Class in com.hazelcast.internal.nearcache.impl.invalidation
 
BatchNearCacheInvalidation() - Constructor for class com.hazelcast.internal.nearcache.impl.invalidation.BatchNearCacheInvalidation
 
BatchNearCacheInvalidation(String, List<Invalidation>) - Constructor for class com.hazelcast.internal.nearcache.impl.invalidation.BatchNearCacheInvalidation
 
batchSize - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateCodec.RequestParameters
The size of batch.
batchSize - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateWithValueCodec.RequestParameters
The size of batch.
batchSize - Variable in class com.hazelcast.client.impl.protocol.codec.FlakeIdGeneratorNewIdBatchCodec.RequestParameters
TODO DOC
batchSize - Variable in class com.hazelcast.client.impl.protocol.codec.FlakeIdGeneratorNewIdBatchCodec.ResponseParameters
TODO DOC
batchSize() - Method in class com.hazelcast.flakeidgen.impl.IdBatch
Returns number of IDs in the set.
before(List<Operation>, Operation) - Static method in class com.hazelcast.collection.impl.CollectionTxnUtil
 
before(Credentials, String, String, String, Parameters) - Method in interface com.hazelcast.security.SecurityInterceptor
 
BEFORE_JOIN_CHECK_FAILURE - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
beforeClusterStateChange(ClusterState, ClusterState, boolean) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
beforeClusterStateChange(ClusterState, ClusterState, boolean) - Method in interface com.hazelcast.instance.impl.NodeExtension
Called before starting a cluster state change transaction.
beforeClusterSwitch(CandidateClusterContext) - Method in interface com.hazelcast.client.impl.connection.ClientConnectionManager
 
beforeClusterSwitch(CandidateClusterContext) - Method in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
beforeGetConnection(Address) - Method in class com.hazelcast.client.impl.connection.ClientConnectionStrategy
The purpose of this method is to validate a connection request by target, and exit the blocking invocation.
beforeGetConnection(Address) - Method in class com.hazelcast.client.impl.connection.nio.DefaultClientConnectionStrategy
 
beforeJoin() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
beforeJoin() - Method in interface com.hazelcast.instance.impl.NodeExtension
Called before node attempts to join to the cluster
BeforeJoinCheckFailureOp - Class in com.hazelcast.internal.cluster.impl.operations
 
BeforeJoinCheckFailureOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.BeforeJoinCheckFailureOp
 
BeforeJoinCheckFailureOp(String) - Constructor for class com.hazelcast.internal.cluster.impl.operations.BeforeJoinCheckFailureOp
 
beforeListenerRegister() - Method in interface com.hazelcast.client.impl.spi.EventHandler
This method is called before registration request is sent to node.
beforeListenerRegister() - Method in class com.hazelcast.client.impl.spi.impl.SmartClientInvocationService.BackupEventHandler
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.collection.impl.collection.CollectionService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cp.internal.datastructures.spi.AbstractCPMigrationAwareService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cp.internal.RaftService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.internal.longregister.LongRegisterService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.map.impl.MapService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.spi.impl.CountingMigrationAwareService
 
beforeMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.partition.MigrationAwareService
Called before migration process starts, on both source and destination members.
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.transaction.impl.xa.XAService
 
beforeOpenConnection(Address) - Method in class com.hazelcast.client.impl.connection.ClientConnectionStrategy
If a new connection is required to open by ClientConnectionManager, this method will be called.
beforeOpenConnection(Address) - Method in class com.hazelcast.client.impl.connection.nio.DefaultClientConnectionStrategy
 
beforeProcess() - Method in class com.hazelcast.client.impl.protocol.task.AbstractAddressMessageTask
Called on node side, before starting any operation.
beforeProcess() - Method in class com.hazelcast.client.impl.protocol.task.AbstractPartitionMessageTask
Called on node side, before starting any operation.
beforeProcess() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapPutMessageTask
 
beforeProcess() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapSetMessageTask
 
beforeProcess() - Method in class com.hazelcast.client.impl.protocol.task.map.MapDeleteMessageTask
 
beforeProcess() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
 
beforeProcess() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
 
beforeProcess() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
 
beforeProcess() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
 
beforeProcess() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
 
beforeResponse() - Method in class com.hazelcast.client.impl.protocol.task.AbstractAddressMessageTask
Called on node side, after process is run and right before sending the response to the client.
beforeResponse() - Method in class com.hazelcast.client.impl.protocol.task.AbstractPartitionMessageTask
Called on node side, after process is run and right before sending the response to the client.
beforeResponse() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapPutMessageTask
 
beforeResponse() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapSetMessageTask
 
beforeResponse() - Method in class com.hazelcast.client.impl.protocol.task.map.MapDeleteMessageTask
 
beforeResponse() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
 
beforeResponse() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
 
beforeResponse() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
 
beforeResponse() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
 
beforeResponse() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
 
beforeRun() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalSubscribeOperation
 
beforeRun() - Method in class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
 
beforeRun() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
 
beforeRun() - Method in class com.hazelcast.cache.impl.operation.CacheOperation
 
beforeRun() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
 
beforeRun() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
 
beforeRun() - Method in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
 
beforeRun() - Method in class com.hazelcast.collection.impl.list.operations.ListRemoveOperation
 
beforeRun() - Method in class com.hazelcast.collection.impl.queue.operations.QueueOperation
 
beforeRun() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitBackupOperation
 
beforeRun() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitOperation
 
beforeRun() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitBackupOperation
 
beforeRun() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitOperation
 
beforeRun() - Method in class com.hazelcast.internal.cluster.impl.operations.CommitClusterStateOp
 
beforeRun() - Method in class com.hazelcast.internal.cluster.impl.operations.LockClusterStateOp
 
beforeRun() - Method in class com.hazelcast.internal.cluster.impl.operations.OnJoinOp
 
beforeRun() - Method in class com.hazelcast.internal.journal.EventJournalReadOperation
The beforeRun is called before either the Operation.run() or the Operation.call() method is called.
beforeRun() - Method in class com.hazelcast.internal.metrics.managementcenter.ReadMetricsOperation
 
beforeRun() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRequest
 
beforeRun() - Method in class com.hazelcast.internal.partition.operation.PromotionCommitOperation
 
beforeRun() - Method in class com.hazelcast.internal.util.executor.HazelcastManagedThread
Called before inner run method and can be overridden to customize.
beforeRun() - Method in class com.hazelcast.map.impl.operation.MapOperation
 
beforeRun() - Method in class com.hazelcast.multimap.impl.operations.ClearOperation
 
beforeRun() - Method in class com.hazelcast.ringbuffer.impl.operations.MergeOperation
 
beforeRun() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
 
beforeRun() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
 
beforeRun() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
 
beforeRun() - Method in class com.hazelcast.spi.impl.operationservice.Operation
The beforeRun is called before either the Operation.run() or the Operation.call() method is called.
beforeRun() - Method in class com.hazelcast.topic.impl.PublishOperation
The beforeRun is called before either the Operation.run() or the Operation.call() method is called.
beforeRun() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionBackupOperation
 
beforeRun() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
 
beforeRun() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionBackupOperation
 
beforeRun() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
 
beforeRunInternal() - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperation
 
beforeRunInternal() - Method in class com.hazelcast.cache.impl.operation.CacheOperation
Implementers can override this method to make a specific execution.
beforeShutdown() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
beforeShutdown() - Method in interface com.hazelcast.instance.impl.NodeExtension
Called before Node.shutdown()
beforeStart(HazelcastClientInstanceImpl) - Method in interface com.hazelcast.client.impl.ClientExtension
Called before client is started
beforeStart(HazelcastClientInstanceImpl) - Method in class com.hazelcast.client.impl.clientside.DefaultClientExtension
 
beforeStart() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
beforeStart() - Method in interface com.hazelcast.instance.impl.NodeExtension
Called before node is started
begin - Variable in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
 
begin() - Method in class com.hazelcast.transaction.impl.SuspendedTransaction
 
begin() - Method in interface com.hazelcast.transaction.impl.Transaction
 
begin() - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
begin() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
 
BEGIN_DATA_STRUCTURE_FLAG - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
BEGIN_FRAGMENT_FLAG - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
BEGIN_FRAME - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
beginTransaction() - Method in class com.hazelcast.client.impl.proxy.txn.TransactionContextProxy
 
beginTransaction() - Method in class com.hazelcast.client.impl.proxy.txn.xa.XATransactionContextProxy
 
beginTransaction() - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
 
beginTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Begins a transaction.
Beta - Annotation Type in com.hazelcast.spi.annotation
An element annotated with this annotation is considered beta status.
between(Comparable, Comparable) - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
between(Comparable, Comparable) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
between(String, Comparable, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a between predicate that will pass items if the value stored under the given item attribute is contained inside the given range.
BETWEEN_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
BetweenPredicate - Class in com.hazelcast.query.impl.predicates
Between Predicate
BetweenPredicate() - Constructor for class com.hazelcast.query.impl.predicates.BetweenPredicate
 
BetweenPredicate(String, Comparable, Comparable) - Constructor for class com.hazelcast.query.impl.predicates.BetweenPredicate
 
BiConsumerEx<T,U> - Interface in com.hazelcast.internal.util.function
Serializable variant of java.util.function.BiConsumer which declares checked exception.
BiFunctionEx<T,U,R> - Interface in com.hazelcast.internal.util.function
Serializable variant of java.util.function.BiFunction which declares checked exception.
BIG_DECIMAL_AVG - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
BIG_DECIMAL_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
BIG_DECIMAL_SUM - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
BIG_INT_AVG - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
BIG_INT_SUM - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
BIG_INTEGER_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
BigDecimalAverageAggregator<I> - Class in com.hazelcast.aggregation.impl
 
BigDecimalAverageAggregator() - Constructor for class com.hazelcast.aggregation.impl.BigDecimalAverageAggregator
 
BigDecimalAverageAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.BigDecimalAverageAggregator
 
bigDecimalAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
BigDecimalSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.BigDecimalSerializer
 
bigDecimalSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
BigDecimalSumAggregator<I> - Class in com.hazelcast.aggregation.impl
 
BigDecimalSumAggregator() - Constructor for class com.hazelcast.aggregation.impl.BigDecimalSumAggregator
 
BigDecimalSumAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.BigDecimalSumAggregator
 
BigIntegerAverageAggregator<I> - Class in com.hazelcast.aggregation.impl
 
BigIntegerAverageAggregator() - Constructor for class com.hazelcast.aggregation.impl.BigIntegerAverageAggregator
 
BigIntegerAverageAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.BigIntegerAverageAggregator
 
bigIntegerAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
BigIntegerSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.BigIntegerSerializer
 
bigIntegerSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
BigIntegerSumAggregator<I> - Class in com.hazelcast.aggregation.impl
 
BigIntegerSumAggregator() - Constructor for class com.hazelcast.aggregation.impl.BigIntegerSumAggregator
 
BigIntegerSumAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.BigIntegerSumAggregator
 
BiInt2ObjectMap<V> - Class in com.hazelcast.internal.util.collection
Map that takes two part int key and associates with an object.
BiInt2ObjectMap() - Constructor for class com.hazelcast.internal.util.collection.BiInt2ObjectMap
Construct an empty map
BiInt2ObjectMap(int, double) - Constructor for class com.hazelcast.internal.util.collection.BiInt2ObjectMap
BiInt2ObjectMap.EntryConsumer<V> - Interface in com.hazelcast.internal.util.collection
Handler for a map entry
binary - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMultiMapConfigCodec.RequestParameters
true to store values in BINARY format or false to store values in OBJECT format.
BinaryInterface - Annotation Type in com.hazelcast.internal.serialization
Indicates that the binary serialized form of the annotated class is used in client-member communication over Hazelcast Open Binary Client Protocol or in other ways which may break Hazelcast or other systems.
BinaryOperationFactory - Class in com.hazelcast.spi.impl.operationservice
An OperationFactory that creates operations by cloning the passed Operation.
BinaryOperationFactory() - Constructor for class com.hazelcast.spi.impl.operationservice.BinaryOperationFactory
 
BinaryOperationFactory(Operation, NodeEngine) - Constructor for class com.hazelcast.spi.impl.operationservice.BinaryOperationFactory
 
BinaryOperationFactory(Data) - Constructor for class com.hazelcast.spi.impl.operationservice.BinaryOperationFactory
 
BinaryOperatorEx<T> - Interface in com.hazelcast.internal.util.function
Serializable variant of java.util.function.BinaryOperator which declares checked exception.
bind(ClientEndpoint) - Method in interface com.hazelcast.client.impl.ClientEngine
Registers client endpoint to endpointManager.
bind(ClientEndpoint) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
bind(ClientEndpoint) - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
BIND_MESSAGE - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
BIND_SPOOFING_CHECKS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Controls whether we apply more strict checks upon BIND requests towards a cluster member.
BindMessage - Class in com.hazelcast.internal.cluster.impl
 
BindMessage() - Constructor for class com.hazelcast.internal.cluster.impl.BindMessage
 
BindMessage(Address, Address, boolean) - Constructor for class com.hazelcast.internal.cluster.impl.BindMessage
 
BindRequest - Class in com.hazelcast.internal.nio.tcp
 
BiPredicateEx<T,U> - Interface in com.hazelcast.internal.util.function
Serializable variant of java.util.function.BiPredicate which declares checked exception.
Bits - Class in com.hazelcast.internal.nio
Access and manipulate bits, bytes, primitives...
BITS_NODE_ID - Static variable in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorProxy
 
BITS_SEQUENCE - Static variable in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorProxy
 
BITS_TIMESTAMP - Static variable in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorProxy
 
BiTuple<X,Y> - Class in com.hazelcast.internal.util
An immutable container of 2 statically typed fields
blacklist(Address, boolean) - Method in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
blacklist(Address, boolean) - Method in interface com.hazelcast.internal.cluster.Joiner
Adds an address to the blacklist.
blacklistedAddresses - Variable in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
BlockingMessageTask - Interface in com.hazelcast.client.impl.protocol.task
Marker interface for tasks that are blocking the running thread by doing remote operation and waiting for the result.
BlockingOperation - Interface in com.hazelcast.spi.impl.operationservice
An interface that can be implemented by an operation that can block.
BlockingResource<W extends WaitKey> - Class in com.hazelcast.cp.internal.datastructures.spi.blocking
Operations on a BlockingResource may not return a response at commit-time.
BlockingResource() - Constructor for class com.hazelcast.cp.internal.datastructures.spi.blocking.BlockingResource
 
BlockingResource(CPGroupId, String) - Constructor for class com.hazelcast.cp.internal.datastructures.spi.blocking.BlockingResource
 
BOOLEAN_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
BOOLEAN_SIZE_IN_BYTES - Static variable in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
BOOLEAN_SIZE_IN_BYTES - Static variable in class com.hazelcast.internal.nio.Bits
Boolean size in bytes
BooleanArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.BooleanArraySerializer
 
BooleanSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.BooleanSerializer
 
BOTH_OF_ENTRIES_HAVE_SAME_PRIORITY_TO_BE_EVICTED - Static variable in class com.hazelcast.internal.eviction.EvictionPolicyComparator
Integer constant for representing behaviour for giving same priority to both of entry to be evicted.
BoundedRangePredicate - Class in com.hazelcast.query.impl.predicates
Range predicate that is bounded on both sides.
BoundedRangePredicate(String, Comparable, boolean, Comparable, boolean) - Constructor for class com.hazelcast.query.impl.predicates.BoundedRangePredicate
Creates a new instance of bounded range predicate.
boundsCheck(int, int, int) - Static method in class com.hazelcast.internal.util.collection.ArrayUtils
Bounds check when copying to/from a buffer
BROADCAST_TX_ROLLBACK - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
broadcastAppendRequest() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Broadcasts append-entries request to all group members according to their nextIndex parameters.
broadcastConfig(IdentifiedDataSerializable) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
broadcastConfig(IdentifiedDataSerializable) - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Registers a dynamic configurations to all cluster members.
broadcastConfigAsync(IdentifiedDataSerializable) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
BroadcastTxRollbackOperation - Class in com.hazelcast.transaction.impl.operations
 
BroadcastTxRollbackOperation() - Constructor for class com.hazelcast.transaction.impl.operations.BroadcastTxRollbackOperation
 
BroadcastTxRollbackOperation(UUID) - Constructor for class com.hazelcast.transaction.impl.operations.BroadcastTxRollbackOperation
 
BufferingInputStream - Class in com.hazelcast.internal.util
InputStream implementation with a configurable buffer.
BufferingInputStream(InputStream, int) - Constructor for class com.hazelcast.internal.util.BufferingInputStream
 
BufferObjectDataInput - Interface in com.hazelcast.internal.nio
 
BufferObjectDataOutput - Interface in com.hazelcast.internal.nio
 
BufferPool - Interface in com.hazelcast.internal.serialization.impl.bufferpool
The BufferPool allows the pooling of the BufferObjectDataInput and BufferObjectDataOutput instances.
BufferPoolFactory - Interface in com.hazelcast.internal.serialization.impl.bufferpool
A factory for creating BufferPool instances.
BufferPoolFactoryImpl - Class in com.hazelcast.internal.serialization.impl.bufferpool
Default BufferPoolFactory implementation.
BufferPoolFactoryImpl() - Constructor for class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolFactoryImpl
 
BufferPoolImpl - Class in com.hazelcast.internal.serialization.impl.bufferpool
Default {BufferPool} implementation.
BufferPoolImpl(InternalSerializationService) - Constructor for class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolImpl
 
bufferPoolThreadLocal - Variable in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
BufferPoolThreadLocal - Class in com.hazelcast.internal.serialization.impl.bufferpool
A thread-local for BufferPool.
BufferPoolThreadLocal(InternalSerializationService, BufferPoolFactory, Supplier<RuntimeException>) - Constructor for class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolThreadLocal
 
bufferSize - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateCodec.RequestParameters
Maximum number of events which can be stored in a buffer of partition.
bufferSize - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateWithValueCodec.RequestParameters
Maximum number of events which can be stored in a buffer of partition.
build() - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
build(ClassLoader) - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
build() - Method in class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
 
build(ClientFailoverConfig) - Method in class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
 
build() - Method in class com.hazelcast.client.config.YamlClientConfigBuilder
 
build(ClassLoader) - Method in class com.hazelcast.client.config.YamlClientConfigBuilder
 
build() - Method in class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
 
build() - Method in class com.hazelcast.cluster.impl.MemberImpl.Builder
 
build() - Method in interface com.hazelcast.config.ConfigBuilder
Builds Config object.
build() - Method in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
 
build() - Method in class com.hazelcast.config.RecentlyActiveSplitBrainProtectionConfigBuilder
 
build() - Method in class com.hazelcast.config.SplitBrainProtectionConfigBuilder
 
build() - Method in class com.hazelcast.config.XmlConfigBuilder
 
build() - Method in class com.hazelcast.config.YamlConfigBuilder
 
BUILD - Static variable in class com.hazelcast.instance.GeneratedBuildProperties
 
build() - Method in interface com.hazelcast.internal.auditlog.EventBuilder
Builds the AuditableEvent instance.
build() - Method in class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService.Builder
 
build() - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
build() - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1.Builder
 
build() - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
build() - Method in class com.hazelcast.internal.util.collection.ImmutableInflatableSet.ImmutableSetBuilder
 
build() - Method in class com.hazelcast.internal.util.collection.InflatableSet.Builder
 
build(Object) - Static method in class com.hazelcast.internal.yaml.YamlDomBuilder
 
build() - Method in class com.hazelcast.map.impl.query.Query.QueryBuilder
 
build() - Method in class com.hazelcast.map.impl.querycache.event.QueryCacheEventDataBuilder
 
build() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
build() - Method in class com.hazelcast.query.impl.getters.Extractors.Builder
 
build() - Method in class com.hazelcast.query.impl.Indexes.Builder
 
buildConfig(Node) - Method in interface com.hazelcast.config.DomConfigProcessor
Traverses the DOM and fills the config
Builder(Address) - Constructor for class com.hazelcast.cluster.impl.MemberImpl.Builder
 
Builder(Map<EndpointQualifier, Address>) - Constructor for class com.hazelcast.cluster.impl.MemberImpl.Builder
 
Builder() - Constructor for class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService.Builder
 
Builder() - Constructor for class com.hazelcast.internal.serialization.impl.AbstractSerializationService.Builder
 
builder() - Static method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1
 
Builder() - Constructor for class com.hazelcast.internal.serialization.impl.SerializationServiceV1.Builder
 
Builder(InternalSerializationService) - Constructor for class com.hazelcast.query.impl.getters.Extractors.Builder
 
BuildInfo - Class in com.hazelcast.instance
 
BuildInfo(String, String, String, int, boolean, byte, String) - Constructor for class com.hazelcast.instance.BuildInfo
 
BuildInfo(String, String, String, int, boolean, byte, String, BuildInfo) - Constructor for class com.hazelcast.instance.BuildInfo
 
BuildInfoPlugin - Class in com.hazelcast.internal.diagnostics
A DiagnosticsPlugin that displays the build info.
BuildInfoPlugin(NodeEngineImpl) - Constructor for class com.hazelcast.internal.diagnostics.BuildInfoPlugin
 
BuildInfoPlugin(ILogger) - Constructor for class com.hazelcast.internal.diagnostics.BuildInfoPlugin
 
BuildInfoProvider - Class in com.hazelcast.instance
Provides information about current Hazelcast build.
buildNumber - Variable in class com.hazelcast.internal.cluster.impl.JoinMessage
 
buildRecordInfo(Record) - Static method in class com.hazelcast.map.impl.record.Records
 
BulkGetCommand - Class in com.hazelcast.internal.ascii.memcache
 
BulkGetCommand(List<String>) - Constructor for class com.hazelcast.internal.ascii.memcache.BulkGetCommand
 
BulkGetCommandProcessor - Class in com.hazelcast.internal.ascii.memcache
 
BulkGetCommandProcessor(TextCommandService, EntryConverter) - Constructor for class com.hazelcast.internal.ascii.memcache.BulkGetCommandProcessor
 
BusySpinIdleStrategy - Class in com.hazelcast.internal.util.concurrent
Busy spin strategy targeted at lowest possible latency.
BusySpinIdleStrategy() - Constructor for class com.hazelcast.internal.util.concurrent.BusySpinIdleStrategy
 
BYTE_ARRAY_ACCESS - Static variable in class com.hazelcast.internal.memory.impl.EndiannessUtil
Accesses bytes in a Java byte array
BYTE_BUFFER_ACCESS - Static variable in class com.hazelcast.internal.memory.impl.EndiannessUtil
Accesses bytes in a Java ByteBuffer
BYTE_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
BYTE_SIZE_IN_BYTES - Static variable in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
BYTE_SIZE_IN_BYTES - Static variable in class com.hazelcast.internal.nio.Bits
Byte size in bytes
ByteAccessStrategy<R> - Interface in com.hazelcast.internal.memory
Access strategy for single memory bytes.
ByteArrayAccessStrategy - Class in com.hazelcast.internal.memory.impl
Implementation of ByteAccessStrategy for Java byte arrays.
ByteArrayCodec - Class in com.hazelcast.client.impl.protocol.codec.builtin
 
ByteArrayProcessor - Interface in com.hazelcast.internal.util
A byte array processor used to produce a byte[] out of the given one.
ByteArraySerializer<T> - Interface in com.hazelcast.nio.serialization
For sample usage custom serialization and other way of custom serialization see StreamSerializer.
byteArrayToLong(byte[]) - Static method in class com.hazelcast.internal.ascii.memcache.MemcacheCommandProcessor
 
ByteBufferAccessStrategy - Class in com.hazelcast.internal.memory.impl
 
byteOrder - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
bytes() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in bytes.
ByteSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.ByteSerializer
 
bytesPending() - Method in class com.hazelcast.internal.networking.nio.NioOutboundPipeline
 
bytesRead() - Method in interface com.hazelcast.internal.networking.Channel
Returns current count of bytes read from the Channel.
bytesRead() - Method in class com.hazelcast.internal.networking.nio.NioChannel
 
bytesToHex(byte[]) - Static method in class com.hazelcast.internal.util.QuickMath
 
bytesToString(byte[], int, int) - Static method in class com.hazelcast.internal.util.StringUtil
Creates a UTF8_CHARSET string from a byte array.
bytesToString(byte[]) - Static method in class com.hazelcast.internal.util.StringUtil
Creates a UTF8_CHARSET string from a byte array.
bytesTransceived() - Method in class com.hazelcast.internal.networking.nio.NioThread
 
bytesWritten() - Method in interface com.hazelcast.internal.networking.Channel
Returns current count of bytes written into the Channel.
bytesWritten() - Method in class com.hazelcast.internal.networking.nio.NioChannel
 

C

cache - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
CACHE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
CACHE_ASSIGN_AND_GET_UUIDS - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CACHE_ASSIGN_AND_GET_UUIDS_FACTORY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CACHE_BROWSER_ENTRY_VIEW - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CACHE_DATA_RECORD - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CACHE_DESTROY_EVENT_CONTEXT - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CACHE_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
CACHE_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
CACHE_EVENT_DATA - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CACHE_EVENT_DATA_SET - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CACHE_EVENT_LISTENER_ADAPTOR - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CACHE_INVALIDATION_MESSAGE_BATCH_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines cache invalidation event batch sending is enabled or not.
CACHE_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines the cache invalidation event batch sending frequency in seconds.
CACHE_INVALIDATION_MESSAGE_BATCH_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines the maximum number of cache invalidation events to be drained and sent to the event listeners in a batch.
CACHE_INVALIDATION_METADATA - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CACHE_INVALIDATION_METADATA_RESPONSE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CACHE_LINE_LENGTH - Static variable in class com.hazelcast.internal.nio.Bits
Length of the data blocks used by the CPU cache sub-system in bytes.
CACHE_LOADER - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
CACHE_MANAGER_PREFIX - Static variable in interface com.hazelcast.cache.HazelcastCacheManager
Hazelcast's CacheManager prefix to be appended to the head of the cache name.
CACHE_MERGING_ENTRY - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
CACHE_NEAR_CACHE_STATE_HOLDER - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CACHE_NOT_EXISTS - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
CACHE_OBJECT_RECORD - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CACHE_PARTITION_EVENT_DATA - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CACHE_PARTITION_LOST_EVENT - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
 
CACHE_PARTITION_LOST_EVENT_FILTER - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CACHE_PARTITION_LOST_LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
CACHE_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
CACHE_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
CACHE_POST_JOIN - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CACHE_PROP - Static variable in class com.hazelcast.spring.cache.HazelcastCacheManager
Property name for hazelcast spring-cache related properties.
CACHE_REPLICATION - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CACHE_SUPPORT_NOT_AVAILABLE_ERROR_MESSAGE - Static variable in interface com.hazelcast.cache.impl.ICacheService
 
CACHE_WRITER - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
CacheAddEntryListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
CacheAddEntryListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
CacheAddEntryListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheAddEntryListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
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
 
CacheAddInvalidationListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
CacheAddInvalidationListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
CacheAddInvalidationListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheAddInvalidationListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheAddNearCacheInvalidationListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds listener to cache.
CacheAddNearCacheInvalidationListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
CacheAddNearCacheInvalidationListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheAddNearCacheInvalidationListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheAddNearCacheInvalidationListenerTask - Class in com.hazelcast.client.impl.protocol.task.cache
 
CacheAddNearCacheInvalidationListenerTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheAddNearCacheInvalidationListenerTask
 
CacheAddPartitionLostListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a CachePartitionLostListener.
CacheAddPartitionLostListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
CacheAddPartitionLostListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheAddPartitionLostListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheAddPartitionLostListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
 
CacheAddPartitionLostListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
 
CacheAssignAndGetUuidsCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
CacheAssignAndGetUuidsCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheAssignAndGetUuidsCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheAssignAndGetUuidsMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
 
CacheAssignAndGetUuidsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsMessageTask
 
CacheAssignAndGetUuidsOperation - Class in com.hazelcast.client.impl.protocol.task.cache
 
CacheAssignAndGetUuidsOperation() - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsOperation
 
CacheAssignAndGetUuidsOperationFactory - Class in com.hazelcast.client.impl.protocol.task.cache
 
CacheAssignAndGetUuidsOperationFactory() - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsOperationFactory
 
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
 
CacheBrowserEntryView() - Constructor for class com.hazelcast.internal.management.request.GetCacheEntryRequest.CacheBrowserEntryView
 
CacheClearBackupOperation - Class in com.hazelcast.cache.impl.operation
Backup operation of CacheClearOperation.
CacheClearBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
 
CacheClearBackupOperation(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
 
CacheClearCodec - Class in com.hazelcast.client.impl.protocol.codec
Clears the contents of the cache, without notifying listeners or CacheWriters.
CacheClearCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheClearCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheClearExpiredOperation - Class in com.hazelcast.cache.impl.operation
 
CacheClearExpiredOperation(int) - Constructor for class com.hazelcast.cache.impl.operation.CacheClearExpiredOperation
 
CacheClearExpiredRecordsTask - Class in com.hazelcast.cache.impl.eviction
Clears expired entries.
CacheClearExpiredRecordsTask(CachePartitionSegment[], NodeEngine) - Constructor for class com.hazelcast.cache.impl.eviction.CacheClearExpiredRecordsTask
 
CacheClearMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
This client request specifically calls CacheClearOperationFactory on the server side.
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
OperationFactory implementation for Clear Operations.
CacheClearOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
 
CacheClearOperationFactory(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
 
CacheClearResponse - Class in com.hazelcast.cache.impl
This class is a simple object wrapper to be used by CacheClearOperation.
CacheClearResponse() - Constructor for class com.hazelcast.cache.impl.CacheClearResponse
 
CacheClearResponse(Object) - Constructor for class com.hazelcast.cache.impl.CacheClearResponse
 
cacheConfig - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
cacheConfig - Variable in class com.hazelcast.client.impl.protocol.codec.CacheCreateConfigCodec.RequestParameters
The cache configuration.
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
 
CacheConfigAccessor - Class in com.hazelcast.config
Accessor for CacheConfig fields
CacheConfigHolder - Class in com.hazelcast.client.impl.protocol.codec.holder
 
CacheConfigHolder(String, String, String, int, int, String, EvictionConfigHolder, WanReplicationRef, String, String, Data, Data, Data, boolean, boolean, boolean, boolean, boolean, HotRestartConfig, EventJournalConfig, String, List<Data>, MergePolicyConfig, boolean, List<ListenerConfigHolder>) - Constructor for class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
CacheConfigHolderCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
CacheConfigReadOnly<K,V> - Class in com.hazelcast.internal.config
Readonly version of CacheConfig
CacheConfigReadOnly(CacheConfig) - Constructor for class com.hazelcast.internal.config.CacheConfigReadOnly
 
CacheConfiguration<K,V> - Interface in com.hazelcast.config
Mutable extension to CompleteConfiguration
CacheContainsKeyCodec - Class in com.hazelcast.client.impl.protocol.codec
Determines if the Cache contains an entry for the specified key.
CacheContainsKeyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheContainsKeyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheContainsKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
This client request specifically calls CacheContainsKeyOperation on the server side.
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
 
cacheContext - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
CacheContext - Class in com.hazelcast.cache.impl
Holds some specific informations for per cache in the node and shared by all partitions of that cache on the node.
CacheContext() - Constructor for class com.hazelcast.cache.impl.CacheContext
 
cacheContexts - Variable in class com.hazelcast.cache.impl.AbstractCacheService
Map from full prefixed cache name to CacheContext
cacheContextsConstructorFunction - Variable in class com.hazelcast.cache.impl.AbstractCacheService
 
CacheCreateConfigCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
CacheCreateConfigCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheCreateConfigCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheCreateConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
Creates the given CacheConfig on all members of the cluster.
CacheCreateConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheCreateConfigMessageTask
 
CacheCreateConfigOperation - Class in com.hazelcast.cache.impl.operation
Deprecated.
as of 3.10 replaced by AddCacheConfigOperation, which is used in conjunction with InvocationUtil.invokeOnStableClusterSerial(NodeEngine, java.util.function.Supplier, int) to reliably broadcast the CacheConfig to all members of the cluster.
CacheCreateConfigOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
Deprecated.
 
CacheCreateConfigOperation(CacheConfig, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
Deprecated.
 
CacheCreateConfigOperation(CacheConfig, boolean, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
Deprecated.
 
CACHED_AS_NULL - Static variable in interface com.hazelcast.internal.nearcache.NearCache
NULL Object
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 contains all the ID hooks for IdentifiedDataSerializable classes used inside the JCache framework.
CacheDataSerializerHook() - Constructor for class com.hazelcast.cache.impl.CacheDataSerializerHook
 
cacheDeserializedValues - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
control caching of de-serialized values.
CacheDeserializedValues - Enum in com.hazelcast.config
Control caching of de-serialized values.
CacheDestroyCodec - Class in com.hazelcast.client.impl.protocol.codec
Closes the cache.
CacheDestroyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheDestroyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheDestroyEventContext - Class in com.hazelcast.cache.impl.tenantcontrol
 
CacheDestroyEventContext() - Constructor for class com.hazelcast.cache.impl.tenantcontrol.CacheDestroyEventContext
 
CacheDestroyEventContext(String) - Constructor for class com.hazelcast.cache.impl.tenantcontrol.CacheDestroyEventContext
 
CacheDestroyMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
 
CacheDestroyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
 
CacheDestroyOperation - Class in com.hazelcast.cache.impl.operation
Destroys the cache on the cluster or on a single node by calling ICacheService.deleteCache(String, UUID, boolean).
CacheDestroyOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheDestroyOperation
 
CacheDestroyOperation(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheDestroyOperation
 
CacheDestroyOperation(String, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheDestroyOperation
 
CachedExecutorServiceDelegate - Class in com.hazelcast.internal.util.executor
 
CachedExecutorServiceDelegate(String, ExecutorService, int, int) - Constructor for class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
CachedQueryEntry<K,V> - Class in com.hazelcast.query.impl
Entry of the Query.
CachedQueryEntry() - Constructor for class com.hazelcast.query.impl.CachedQueryEntry
 
CachedQueryEntry(InternalSerializationService, Data, Object, Extractors) - Constructor for class com.hazelcast.query.impl.CachedQueryEntry
 
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
 
CacheEntryCountResolver - Class in com.hazelcast.cache.impl
Contract point for tracking count of stored cache entries.
CacheEntryCountResolver() - Constructor for class com.hazelcast.cache.impl.CacheEntryCountResolver
 
cacheEntryCountResolver - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
CacheEntryEventImpl<K,V> - Class in com.hazelcast.cache.impl
CacheEntryEvent implementation is the actual event object received by sub-interfaces of CacheEntryListener.
CacheEntryEventImpl(ICache<K, V>, EventType, K, V, V) - Constructor for class com.hazelcast.cache.impl.CacheEntryEventImpl
 
CacheEntryIterationResult - Class in com.hazelcast.cache.impl
Response data object returned by CacheEntryIteratorOperation.
CacheEntryIterationResult() - Constructor for class com.hazelcast.cache.impl.CacheEntryIterationResult
 
CacheEntryIterationResult(List<Map.Entry<Data, Data>>, int) - Constructor for class com.hazelcast.cache.impl.CacheEntryIterationResult
 
CacheEntryIteratorOperation - Class in com.hazelcast.cache.impl.operation
Provides iterator functionality for ICache.
CacheEntryIteratorOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheEntryIteratorOperation
 
CacheEntryIteratorOperation(String, int, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheEntryIteratorOperation
 
cacheEntryListenerDeregistered(String, CacheEntryListenerConfiguration) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
CacheEntryListenerProvider<K,V> - Interface in com.hazelcast.cache.impl
Provides underlying (wrapped) CacheEntryListener instance.
cacheEntryListenerRegistered(String, CacheEntryListenerConfiguration) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
cacheEntryListeners - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
cache entry listeners configuration
CacheEntryProcessorCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
CacheEntryProcessorCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheEntryProcessorCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
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
This client request specifically calls CacheEntryProcessorOperation on the server side.
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
 
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
 
CacheEntryView<K,V> - Interface in com.hazelcast.cache
Entry info for cache record.
CacheEntryViews - Class in com.hazelcast.cache.impl
A class providing static factory methods that create various entry view objects.
CacheEntryViews.CacheEntryViewType - Enum in com.hazelcast.cache.impl
Types of built-in CacheEntryView implementations.
CacheEventContext - Class in com.hazelcast.cache.impl
Wrapper class for parameters of ICacheService.publishEvent(CacheEventContext)
CacheEventContext() - Constructor for class com.hazelcast.cache.impl.CacheEventContext
 
CacheEventContextUtil - Class in com.hazelcast.cache.impl
Utility class to create CacheEventContext instances
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.custom
 
CacheEventDataImpl - Class in com.hazelcast.cache.impl
Implementation of CacheEventData.
CacheEventDataImpl() - Constructor for class com.hazelcast.cache.impl.CacheEventDataImpl
 
CacheEventDataImpl(String, CacheEventType, Data, Data, Data, boolean) - Constructor for class com.hazelcast.cache.impl.CacheEventDataImpl
 
cacheEventHandler - Variable in class com.hazelcast.cache.impl.AbstractCacheService
 
CacheEventHandler - Class in com.hazelcast.cache.impl
Sends cache invalidation events in batch or single as configured.
CacheEventJournal - Interface in com.hazelcast.cache.impl.journal
The event journal is a container for events related to a data structure.
CacheEventJournalFunctions - Class in com.hazelcast.cache.impl.journal
Utility functions used from Jet.
CacheEventJournalReadCodec - Class in com.hazelcast.client.impl.protocol.codec
Reads from the cache event journal in batches.
CacheEventJournalReadCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheEventJournalReadCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheEventJournalReadOperation<K,V,T> - Class in com.hazelcast.cache.impl.journal
Reads from the cache event journal in batches.
CacheEventJournalReadOperation() - Constructor for class com.hazelcast.cache.impl.journal.CacheEventJournalReadOperation
 
CacheEventJournalReadOperation(String, long, int, int, Predicate<? super EventJournalCacheEvent<K, V>>, Function<? super EventJournalCacheEvent<K, V>, ? extends T>) - Constructor for class com.hazelcast.cache.impl.journal.CacheEventJournalReadOperation
 
CacheEventJournalReadResultSetImpl<K,V,T> - Class in com.hazelcast.cache.impl.journal
 
CacheEventJournalReadResultSetImpl() - Constructor for class com.hazelcast.cache.impl.journal.CacheEventJournalReadResultSetImpl
 
CacheEventJournalReadTask<K,V,T> - Class in com.hazelcast.client.impl.protocol.task.cache
Reads from the cache event journal in batches.
CacheEventJournalReadTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalReadTask
 
CacheEventJournalSubscribeCodec - Class in com.hazelcast.client.impl.protocol.codec
Performs the initial subscription to the cache event journal.
CacheEventJournalSubscribeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheEventJournalSubscribeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheEventJournalSubscribeOperation - Class in com.hazelcast.cache.impl.journal
Performs the initial subscription to the cache event journal.
CacheEventJournalSubscribeOperation() - Constructor for class com.hazelcast.cache.impl.journal.CacheEventJournalSubscribeOperation
 
CacheEventJournalSubscribeOperation(String) - Constructor for class com.hazelcast.cache.impl.journal.CacheEventJournalSubscribeOperation
 
CacheEventJournalSubscribeTask - Class in com.hazelcast.client.impl.protocol.task.cache
Performs the initial subscription to the cache event journal.
CacheEventJournalSubscribeTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalSubscribeTask
 
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() - Constructor for class com.hazelcast.cache.impl.CacheEventListenerAdaptor
 
CacheEventListenerAdaptor(ICache<K, V>, CacheEntryListenerConfiguration<K, V>, SerializationService) - Constructor for class com.hazelcast.cache.impl.CacheEventListenerAdaptor
 
cacheEventNewValue() - Static method in class com.hazelcast.cache.impl.journal.CacheEventJournalFunctions
 
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
 
cacheEventToEntry() - Static method in class com.hazelcast.cache.impl.journal.CacheEventJournalFunctions
 
CacheEventType - Enum in com.hazelcast.cache
Hazelcast JCache implementation's internal event types.
CacheEvictionPolicyComparator<K,V> - Class in com.hazelcast.cache
Cache specific EvictionPolicyComparator for comparing CacheEntryViews to be evicted.
CacheEvictionPolicyComparator() - Constructor for class com.hazelcast.cache.CacheEvictionPolicyComparator
 
CacheExpireBatchBackupOperation - Class in com.hazelcast.cache.impl.operation
Used to transfer expired keys from owner replica to backup replicas.
CacheExpireBatchBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheExpireBatchBackupOperation
 
CacheExpireBatchBackupOperation(String, Collection<ExpiredKey>, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheExpireBatchBackupOperation
 
CacheFetchNearCacheInvalidationMetadataCodec - Class in com.hazelcast.client.impl.protocol.codec
Fetches invalidation metadata from partitions of map.
CacheFetchNearCacheInvalidationMetadataCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheFetchNearCacheInvalidationMetadataCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheFetchNearCacheInvalidationMetadataTask - Class in com.hazelcast.client.impl.protocol.task.cache
 
CacheFetchNearCacheInvalidationMetadataTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheFetchNearCacheInvalidationMetadataTask
 
CacheGetAllCodec - Class in com.hazelcast.client.impl.protocol.codec
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.
CacheGetAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheGetAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheGetAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
This client request specifically calls CacheGetAllOperationFactory on the server side.
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
Factory implementation for CacheGetAllOperation.
CacheGetAllOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
 
CacheGetAllOperationFactory(String, Set<Data>, ExpiryPolicy) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
 
CacheGetAndRemoveCodec - Class in com.hazelcast.client.impl.protocol.codec
Atomically removes the entry for a key only if currently mapped to some value.
CacheGetAndRemoveCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheGetAndRemoveCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheGetAndRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
This client request specifically calls CacheGetAndRemoveOperation on the server side.
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
 
CacheGetAndReplaceCodec - Class in com.hazelcast.client.impl.protocol.codec
Atomically replaces the assigned value of the given key by the specified value using a custom javax.cache.expiry.ExpiryPolicy and returns the previously assigned value.
CacheGetAndReplaceCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheGetAndReplaceCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheGetAndReplaceMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
This client request specifically calls CacheGetAndReplaceOperation on the server side.
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
 
CacheGetCodec - Class in com.hazelcast.client.impl.protocol.codec
Retrieves the mapped value of the given key using a custom javax.cache.expiry.ExpiryPolicy.
CacheGetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheGetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheGetConfigCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
CacheGetConfigCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheGetConfigCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheGetConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
This client request specifically calls CacheGetConfigOperation on the server side.
CacheGetConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheGetConfigMessageTask
 
CacheGetConfigOperation - Class in com.hazelcast.cache.impl.operation
Gets a cache configuration or creates one, if a matching cache config is found in this member's config.
CacheGetConfigOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
 
CacheGetConfigOperation(String, String) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
 
CacheGetInvalidationMetaDataOperation - Class in com.hazelcast.cache.impl.operation
 
CacheGetInvalidationMetaDataOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation
 
CacheGetInvalidationMetaDataOperation(List<String>) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation
 
CacheGetInvalidationMetaDataOperation.MetaDataResponse - Class in com.hazelcast.cache.impl.operation
 
CacheGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
This client request specifically calls CacheGetOperation on the server side.
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
 
CacheIterateCodec - Class in com.hazelcast.client.impl.protocol.codec
The ordering of iteration over entries is undefined.
CacheIterateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheIterateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheIterateEntriesCodec - Class in com.hazelcast.client.impl.protocol.codec
Fetches specified number of entries from the specified partition starting from specified table index.
CacheIterateEntriesCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheIterateEntriesCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheIterateEntriesMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
This client request specifically calls CacheEntryIteratorOperation on the server side.
CacheIterateEntriesMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheIterateEntriesMessageTask
 
CacheIterateMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
This client request specifically calls CacheKeyIteratorOperation on the server side.
CacheIterateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheIterateMessageTask
 
CacheKeyIterationResult - Class in com.hazelcast.cache.impl
Response data object returned by CacheKeyIteratorOperation.
CacheKeyIterationResult() - Constructor for class com.hazelcast.cache.impl.CacheKeyIterationResult
 
CacheKeyIterationResult(List<Data>, int) - Constructor for class com.hazelcast.cache.impl.CacheKeyIterationResult
 
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
 
CacheListenerRegistrationCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
CacheListenerRegistrationCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheListenerRegistrationCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheListenerRegistrationMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
This client request specifically calls CacheListenerRegistrationOperation on the server side.
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
 
CacheLoadAllCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
CacheLoadAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheLoadAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheLoadAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
This client request specifically calls CacheLoadAllOperationFactory on the server side.
CacheLoadAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
 
CacheLoadAllOperation - Class in com.hazelcast.cache.impl.operation
Loads all entries of the keys to partition record store ICacheRecordStore.
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
Factory implementation for CacheLoadAllOperation.
CacheLoadAllOperationFactory(String, Set<Data>, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
 
CacheLoadAllOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
 
cacheLoader - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
cacheLoader - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
Factory name of cache loader factory class, if one is configured
cacheLoaderFactory - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
name of cache loader factory class, if one is configured
cacheLoaderFactory - Variable in class com.hazelcast.config.AbstractCacheConfig
The Factory for the CacheLoader.
CacheManagementConfigCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
CacheManagementConfigCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheManagementConfigCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheManagementConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
This client request specifically calls CacheManagementConfigOperation on the server side.
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
 
CacheManagerBeanDefinitionParser - Class in com.hazelcast.spring
Bean definition parser for JCache CacheManager.
CacheManagerBeanDefinitionParser() - Constructor for class com.hazelcast.spring.CacheManagerBeanDefinitionParser
 
CacheMergeOperation - Class in com.hazelcast.cache.impl.operation
Contains multiple merging entries for split-brain healing with a SplitBrainMergePolicy.
CacheMergeOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheMergeOperation
 
CacheMergeOperation(String, List<SplitBrainMergeTypes.CacheMergeTypes>, SplitBrainMergePolicy<Data, SplitBrainMergeTypes.CacheMergeTypes>) - Constructor for class com.hazelcast.cache.impl.operation.CacheMergeOperation
 
CacheMergeOperationFactory - Class in com.hazelcast.cache.impl.operation
Inserts the merging entries for all partitions of a member via locally invoked CacheMergeOperation.
CacheMergeOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheMergeOperationFactory
 
CacheMergeOperationFactory(String, int[], List<SplitBrainMergeTypes.CacheMergeTypes>[], SplitBrainMergePolicy<Data, SplitBrainMergeTypes.CacheMergeTypes>) - Constructor for class com.hazelcast.cache.impl.operation.CacheMergeOperationFactory
 
CacheMergingEntryImpl - Class in com.hazelcast.spi.impl.merge
CacheMergingEntryImpl() - Constructor for class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
CacheMergingEntryImpl(SerializationService) - Constructor for class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
CacheMXBeanImpl - Class in com.hazelcast.cache.impl
Implementation of CacheMXBean.
CacheMXBeanImpl(CacheConfig) - Constructor for class com.hazelcast.cache.impl.CacheMXBeanImpl
 
cacheName - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryDestroyCacheCodec.RequestParameters
Name of query cache.
cacheName - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryMadePublishableCodec.RequestParameters
Name of query cache.
cacheName - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateCodec.RequestParameters
Name of query cache.
cacheName - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateWithValueCodec.RequestParameters
Name of the cache for query cache.
cacheName - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQuerySetReadCursorCodec.RequestParameters
Name of query cache.
CacheNearCacheStateHolder - Class in com.hazelcast.cache.impl.operation
Holder for Near Cache metadata.
CacheNearCacheStateHolder() - Constructor for class com.hazelcast.cache.impl.operation.CacheNearCacheStateHolder
 
CacheNearCacheStateHolder(CacheReplicationOperation) - Constructor for class com.hazelcast.cache.impl.operation.CacheNearCacheStateHolder
 
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
 
CacheOperation - Class in com.hazelcast.cache.impl.operation
Base Cache Operation.
CacheOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheOperation
 
CacheOperation(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheOperation
 
CacheOperation(String, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheOperation
 
CacheOperationProvider - Interface in com.hazelcast.cache.impl
Provide InMemoryFormat specific operations for cache
CachePartitionEventData - Class in com.hazelcast.cache.impl
 
CachePartitionEventData() - Constructor for class com.hazelcast.cache.impl.CachePartitionEventData
 
CachePartitionEventData(String, int, Member) - Constructor for class com.hazelcast.cache.impl.CachePartitionEventData
 
CachePartitionIterator<K,V> - Class in com.hazelcast.cache.impl
 
CachePartitionIterator(CacheProxy<K, V>, int, int, boolean) - Constructor for class com.hazelcast.cache.impl.CachePartitionIterator
 
CachePartitionLostEvent - Class in com.hazelcast.cache.impl.event
Used to provide information about the lost partition of a cache.
CachePartitionLostEvent(Object, Member, int, int) - Constructor for class com.hazelcast.cache.impl.event.CachePartitionLostEvent
 
CachePartitionLostEventFilter - Class in com.hazelcast.cache.impl.event
Used to filter partition lost listener events
CachePartitionLostEventFilter() - Constructor for class com.hazelcast.cache.impl.event.CachePartitionLostEventFilter
 
CachePartitionLostListener - Interface in com.hazelcast.cache.impl.event
Invoked when owner and all backups of a partition are lost for a specific cache.
CachePartitionLostListenerConfig - Class in com.hazelcast.config
Configuration for CachePartitionLostListener
CachePartitionLostListenerConfig() - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
 
CachePartitionLostListenerConfig(String) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
 
CachePartitionLostListenerConfig(CachePartitionLostListener) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
 
CachePartitionLostListenerConfig(CachePartitionLostListenerConfig) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
 
CachePartitionLostListenerConfigReadOnly - Class in com.hazelcast.internal.config
Read-Only Configuration for CachePartitionLostListener
CachePartitionLostListenerConfigReadOnly(CachePartitionLostListenerConfig) - Constructor for class com.hazelcast.internal.config.CachePartitionLostListenerConfigReadOnly
 
CachePartitionSegment - Class in com.hazelcast.cache.impl
Responsible for all cache data of a partition.
CachePartitionSegment(AbstractCacheService, int) - Constructor for class com.hazelcast.cache.impl.CachePartitionSegment
 
CachePermission - Class in com.hazelcast.security.permission
 
CachePermission(String, String...) - Constructor for class com.hazelcast.security.permission.CachePermission
 
CacheProxy<K,V> - Class in com.hazelcast.cache.impl
ICache implementation
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
 
CachePutAllCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
CachePutAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CachePutAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CachePutAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
This client request specifically calls CachePutAllOperation on the server side.
CachePutAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CachePutAllMessageTask
 
CachePutAllOperation - Class in com.hazelcast.cache.impl.operation
 
CachePutAllOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutAllOperation
 
CachePutAllOperation(String, List<Map.Entry<Data, Data>>, ExpiryPolicy, int) - Constructor for class com.hazelcast.cache.impl.operation.CachePutAllOperation
 
CachePutBackupOperation - Class in com.hazelcast.cache.impl.operation
Backup operation for the operation of adding cache entries into record stores.
CachePutBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutBackupOperation
 
CachePutBackupOperation(String, Data, CacheRecord) - Constructor for class com.hazelcast.cache.impl.operation.CachePutBackupOperation
 
CachePutBackupOperation(String, Data, CacheRecord, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CachePutBackupOperation
 
CachePutCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
CachePutCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CachePutCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
cachePutEvents() - Static method in class com.hazelcast.cache.impl.journal.CacheEventJournalFunctions
 
CachePutIfAbsentCodec - Class in com.hazelcast.client.impl.protocol.codec
Associates the specified key with the given value if and only if there is not yet a mapping defined for the specified key.
CachePutIfAbsentCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CachePutIfAbsentCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CachePutIfAbsentMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
This client request specifically calls CachePutIfAbsentOperation on the server side.
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
 
CachePutMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
This client request specifically calls CachePutOperation on the server side.
CachePutMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CachePutMessageTask
 
CachePutOperation - Class in com.hazelcast.cache.impl.operation
CachePutOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutOperation
 
CachePutOperation(String, Data, Data, ExpiryPolicy, boolean, int) - Constructor for class com.hazelcast.cache.impl.operation.CachePutOperation
 
CacheRecord<V,E> - 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.AbstractCacheRecordStore
 
CacheRecordFactory<R extends CacheRecord> - Class in com.hazelcast.cache.impl.record
Provides factory for CacheRecord.
CacheRecordFactory(InMemoryFormat, SerializationService) - Constructor for class com.hazelcast.cache.impl.record.CacheRecordFactory
 
CacheRecordHashMap - Class in com.hazelcast.cache.impl.record
 
CacheRecordHashMap(SerializationService, int, CacheContext) - Constructor for class com.hazelcast.cache.impl.record.CacheRecordHashMap
 
CacheRecordMap<K extends Data,V extends CacheRecord> - Interface in com.hazelcast.cache.impl.record
Contract point for storing CacheRecords.
cacheRecordStore - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
CacheRecordStore - Class in com.hazelcast.cache.impl
On-Heap implementation of the ICacheRecordStore
CacheRecordStore(String, int, NodeEngine, AbstractCacheService) - Constructor for class com.hazelcast.cache.impl.CacheRecordStore
 
CacheRemoveAllBackupOperation - Class in com.hazelcast.cache.impl.operation
Backup operation of CacheRemoveAllOperation.
CacheRemoveAllBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
 
CacheRemoveAllBackupOperation(String, Set<Data>) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
 
CacheRemoveAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes all of the mappings from this cache.
CacheRemoveAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheRemoveAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheRemoveAllKeysCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes entries for the specified keys.
CacheRemoveAllKeysCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheRemoveAllKeysCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheRemoveAllKeysMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
This client request specifically calls CacheRemoveAllOperationFactory on the server side.
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
This client request specifically calls CacheRemoveAllOperationFactory on the server side.
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
OperationFactory implementation for RemoveAll Operations.
CacheRemoveAllOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
 
CacheRemoveAllOperationFactory(String, Set<Data>, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
 
CacheRemoveBackupOperation - Class in com.hazelcast.cache.impl.operation
Backup operation used by remove operations.
CacheRemoveBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
 
CacheRemoveBackupOperation(String, Data) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
 
CacheRemoveBackupOperation(String, Data, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
 
CacheRemoveCodec - Class in com.hazelcast.client.impl.protocol.codec
Atomically removes the mapping for a key only if currently mapped to the given value.
CacheRemoveCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheRemoveCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheRemoveEntryListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
CacheRemoveEntryListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheRemoveEntryListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
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
 
CacheRemoveInvalidationListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
CacheRemoveInvalidationListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheRemoveInvalidationListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
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
 
CacheRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
This client request specifically calls CacheRemoveOperation on the server side.
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
 
CacheRemovePartitionLostListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the specified cache partition lost listener.
CacheRemovePartitionLostListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheRemovePartitionLostListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheRemovePartitionLostListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
 
CacheRemovePartitionLostListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
 
CacheReplaceCodec - Class in com.hazelcast.client.impl.protocol.codec
Atomically replaces the currently assigned value for the given key with the specified newValue if and only if the currently assigned value equals the value of oldValue using a custom javax.cache.expiry.ExpiryPolicy If the cache is configured for write-through operation mode, the underlying configured javax.cache.integration.CacheWriter might be called to store the value of the key to any kind of external resource.
CacheReplaceCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheReplaceCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheReplaceMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
This client request specifically calls CachePutOperation on the server side.
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
 
CacheReplicationOperation - Class in com.hazelcast.cache.impl.operation
Replication operation is the data migration operation of CacheRecordStore.
CacheReplicationOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheReplicationOperation
 
cacheResourcesConstructorFunction - Variable in class com.hazelcast.cache.impl.AbstractCacheService
 
cacheResourcesMutexFactory - Variable in class com.hazelcast.cache.impl.AbstractCacheService
 
caches - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
cacheService - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
cacheService - Variable in class com.hazelcast.cache.impl.CachePartitionSegment
 
CacheService - Class in com.hazelcast.cache.impl
Cache Service is the main access point of JCache implementation.
CacheService() - Constructor for class com.hazelcast.cache.impl.CacheService
 
cacheService - Variable in class com.hazelcast.cache.impl.operation.CacheOperation
 
CacheSetExpiryPolicyBackupOperation - Class in com.hazelcast.cache.impl.operation
 
CacheSetExpiryPolicyBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheSetExpiryPolicyBackupOperation
 
CacheSetExpiryPolicyBackupOperation(String, List<Data>, Data) - Constructor for class com.hazelcast.cache.impl.operation.CacheSetExpiryPolicyBackupOperation
 
CacheSetExpiryPolicyCodec - Class in com.hazelcast.client.impl.protocol.codec
Associates the specified key with the given ExpiryPolicy.
CacheSetExpiryPolicyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheSetExpiryPolicyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheSetExpiryPolicyMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
 
CacheSetExpiryPolicyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheSetExpiryPolicyMessageTask
 
CacheSetExpiryPolicyOperation - Class in com.hazelcast.cache.impl.operation
 
CacheSetExpiryPolicyOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheSetExpiryPolicyOperation
 
CacheSetExpiryPolicyOperation(String, List<Data>, Data) - Constructor for class com.hazelcast.cache.impl.operation.CacheSetExpiryPolicyOperation
 
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.DurationConfig - Class in com.hazelcast.config
Represents duration configuration with duration amount and time unit for the "TimedExpiryPolicyFactoryConfig".
CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig - Class in com.hazelcast.config
Represents configuration for time based "ExpiryPolicyFactory" with duration and time unit.
CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType - Enum in com.hazelcast.config
Represents type of the "TimedExpiryPolicyFactoryConfig".
CacheSimpleConfigReadOnly - Class in com.hazelcast.internal.config
Readonly version of CacheSimpleConfig
CacheSimpleConfigReadOnly(CacheSimpleConfig) - Constructor for class com.hazelcast.internal.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
 
CacheSimpleEntryListenerConfigCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
CacheSimpleEntryListenerConfigReadOnly - Class in com.hazelcast.internal.config
Readonly version of CacheSimpleEntryListenerConfig
CacheSimpleEntryListenerConfigReadOnly(CacheSimpleEntryListenerConfig) - Constructor for class com.hazelcast.internal.config.CacheSimpleEntryListenerConfigReadOnly
 
CacheSizeCodec - Class in com.hazelcast.client.impl.protocol.codec
Total entry count
CacheSizeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheSizeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CacheSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
This client request specifically calls CacheSizeOperationFactory on the server side.
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
Factory implementation of CacheSizeOperation.
CacheSizeOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
 
CacheSizeOperationFactory(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
 
CacheStatistics - Interface in com.hazelcast.cache
Cache statistics
cacheStatisticsConstructorFunction - Variable in class com.hazelcast.cache.impl.AbstractCacheService
 
CacheStatisticsImpl - Class in com.hazelcast.cache.impl
CacheStatistics implementation for ICache.
CacheStatisticsImpl(long) - Constructor for class com.hazelcast.cache.impl.CacheStatisticsImpl
 
CacheStatisticsImpl(long, CacheEntryCountResolver) - Constructor for class com.hazelcast.cache.impl.CacheStatisticsImpl
 
CacheStatisticsMXBeanImpl - Class in com.hazelcast.cache.impl
Implementation of CacheStatisticsMXBean
CacheStatisticsMXBeanImpl(CacheStatisticsImpl) - Constructor for class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
 
CacheSyncListenerCompleter - Interface in com.hazelcast.cache.impl
used to state that a sync event completed and any resources waiting for it should be released
CacheUtil - Class in com.hazelcast.cache
Utility class for various cache related operations to be used by our internal structure and end user.
CacheWanEventPublisher - Interface in com.hazelcast.cache.impl.event
This interface provides methods to publish wan replication events from cache operations.
cacheWriter - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
cacheWriter - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
Factory name of cache writer factory class, if one is configured
cacheWriterFactory - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
name of cache writer factory class, if one is configured
cacheWriterFactory - Variable in class com.hazelcast.config.AbstractCacheConfig
The Factory for the CacheWriter.
cachingProvider - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
calculateEntryCost(K, V) - Method in interface com.hazelcast.map.impl.EntryCostEstimator
Calculate the entry's cost in memory
calculateExpirationWithDelay(long, long, boolean) - Static method in class com.hazelcast.map.impl.ExpirationTimeSetter
On backup partitions, this method delays key's expiration.
calculateInitialCapacity(int) - Static method in class com.hazelcast.internal.util.MapUtil
Returns the initial hash map capacity needed for the expected map size.
calculateMaxPartitionSize(int, int) - Static method in class com.hazelcast.cache.impl.maxsize.impl.EntryCountCacheEvictionChecker
 
calculateObjectName(String, String, boolean) - Static method in class com.hazelcast.cache.impl.MXBeanUtil
Creates an object name using the scheme.
calculatePartitionHash(Object, PartitioningStrategy) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
calculateValueCost(V) - Method in interface com.hazelcast.map.impl.EntryCostEstimator
Calculate the entry's value cost in memory
calculateVersion(String) - Static method in class com.hazelcast.instance.BuildInfo
 
call() - Method in class com.hazelcast.client.impl.protocol.task.AbstractCallableMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.AbstractRemoveListenerMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.AbstractTransactionalMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.AddBackupListenerMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionListenerMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddEntryListenerMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddNearCacheInvalidationListenerTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.cache.Pre38CacheAddInvalidationListenerTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.ClientStatisticsMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetConfiguredReplicaCountMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorIsShutdownMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorShutdownMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
The partitions can be empty on the response see ClientPartitionListenerService.getPartitions(PartitionTableView)
call() - Method in class com.hazelcast.client.impl.protocol.task.IsFailoverSupportedMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddListenerMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapAddEntryListenerMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddListenerMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapDestroyCacheMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteWithPredicateMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateWithValueMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.multimap.AbstractMultiMapAddEntryListenerMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddListenerMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicAddMessageListenerMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAClearRemoteTransactionMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCommitMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCreateMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionPrepareMessageTask
 
call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionRollbackMessageTask
 
call() - Method in class com.hazelcast.console.Echo
 
call() - Method in class com.hazelcast.console.SimulateLoadTask
 
call() - Method in class com.hazelcast.cp.internal.operation.RestartCPMemberOp
 
call() - Method in class com.hazelcast.cp.internal.operation.TransferLeadershipOp
 
call() - Method in class com.hazelcast.cp.internal.operation.unsafe.AbstractUnsafeRaftOp
 
call() - Method in class com.hazelcast.executor.impl.RunnableAdapter
 
call() - Method in class com.hazelcast.internal.partition.operation.MigrationRequestOperation
 
call() - Method in class com.hazelcast.internal.partition.operation.PromotionCommitOperation
 
call() - Method in class com.hazelcast.map.impl.operation.EntryOperation
 
call() - Method in class com.hazelcast.map.impl.query.QueryOperation
 
call() - Method in class com.hazelcast.scheduledexecutor.impl.NamedTaskDecorator
 
call() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledRunnableAdapter
 
call() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation
 
call() - Method in class com.hazelcast.spi.impl.operationservice.Operation
Call the operation and returns the CallStatus.
CALL_TIMEOUT_RESPONSE - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
callable - Variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorSubmitToPartitionCodec.RequestParameters
The callable object to be executed.
callable - Variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToAddressCodec.RequestParameters
The callable object to be executed.
callable - Variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToPartitionCodec.RequestParameters
The callable object to be executed.
CALLABLE_TASK - Static variable in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
 
CallableTaskOperation - Class in com.hazelcast.executor.impl.operations
 
CallableTaskOperation() - Constructor for class com.hazelcast.executor.impl.operations.CallableTaskOperation
 
CallableTaskOperation(String, UUID, Data) - Constructor for class com.hazelcast.executor.impl.operations.CallableTaskOperation
 
callAfterStoreListeners(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
 
callBeforeStoreListeners(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
 
caller - Variable in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
 
CALLER_NOT_MEMBER - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
CALLER_RUNS - Static variable in class com.hazelcast.internal.util.ConcurrencyUtil
The Caller runs executor is an Executor that executes the task on the calling thread.
CALLER_RUNS_EXECUTOR - Static variable in class com.hazelcast.internal.util.InvocationUtil
An executor utility to run callbacks on the caller thread.
callerAddress - Variable in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKey
 
callerAddress() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKey
Returns address of the caller which created this wait key
CallerAware - Interface in com.hazelcast.cp.internal
An abstraction to implement blocking Raft ops.
CallerNotMemberException - Exception in com.hazelcast.spi.exception
A RetryableHazelcastException that indicates that an operation was sent by a machine which isn't member in the cluster when the operation is executed.
CallerNotMemberException(Address, Address, int, String, String) - Constructor for exception com.hazelcast.spi.exception.CallerNotMemberException
 
CallerNotMemberException(String) - Constructor for exception com.hazelcast.spi.exception.CallerNotMemberException
 
CallerProvenance - Enum in com.hazelcast.wan.impl
Caller operations' origin.
CallerRunsAccumulationExecutor - Class in com.hazelcast.map.impl.query
Implementation of the AccumulationExecutor that runs the accumulation in the calling thread in a sequential fashion.
CallerRunsAccumulationExecutor(SerializationService) - Constructor for class com.hazelcast.map.impl.query.CallerRunsAccumulationExecutor
 
CallerRunsPartitionScanExecutor - Class in com.hazelcast.map.impl.query
Implementation of the PartitionScanExecutor which executes the partition scan in a sequential-fashion in the calling thread.
CallerRunsPartitionScanExecutor(PartitionScanRunner) - Constructor for class com.hazelcast.map.impl.query.CallerRunsPartitionScanExecutor
 
callId - Variable in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKey
 
callId() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKey
Returns the call id which created this wait key
callId - Variable in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
 
CallIdFactory - Class in com.hazelcast.spi.impl.sequence
 
CallIdSequence - Interface in com.hazelcast.spi.impl.sequence
Responsible for generating invocation callIds.
CallIdSequenceWithBackpressure - Class in com.hazelcast.spi.impl.sequence
A CallIdSequence that provides backpressure by taking the number of in-flight operations into account when before creating a new call-id.
CallIdSequenceWithBackpressure(int, long, ConcurrencyDetection) - Constructor for class com.hazelcast.spi.impl.sequence.CallIdSequenceWithBackpressure
 
CallIdSequenceWithoutBackpressure - Class in com.hazelcast.spi.impl.sequence
 
CallIdSequenceWithoutBackpressure() - Constructor for class com.hazelcast.spi.impl.sequence.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
 
CallsPerMember - Class in com.hazelcast.spi.impl.operationservice
Implements LiveOperations and additionally collects the call IDs of operations on remote members whose cancellation was requested.
CallsPerMember(Address) - Constructor for class com.hazelcast.spi.impl.operationservice.CallsPerMember
 
CallStatus - Class in com.hazelcast.spi.impl.operationservice
The result of an Operation.call().
CallStatus(int) - Constructor for class com.hazelcast.spi.impl.operationservice.CallStatus
 
callTimeout - Variable in class com.hazelcast.spi.impl.operationservice.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, UUID, long) - Method in interface com.hazelcast.internal.locksupport.LockStore
Return if the key can be locked by the caller and thread ID.
canAcquireLock(Data, UUID, long) - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
canAcquireLock(Data, UUID, long) - Method in class com.hazelcast.internal.locksupport.LockStoreProxy
 
canAcquireLock(Data, UUID, long) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
canAcquireLock(Data, UUID, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
canAcquireLock(Data, UUID, long) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
CanCancelOperations - Interface in com.hazelcast.internal.services
Implemented by a service that can cancel its operations.
cancel(boolean) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
cancel(boolean) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledFutureProxy
 
cancel(boolean) - Method in class com.hazelcast.client.impl.proxy.IExecutorDelegatingFuture
 
cancel(UUID, boolean) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
 
cancel(boolean) - Method in class com.hazelcast.internal.util.executor.CompletableFutureTask
 
cancel(K) - Method in interface com.hazelcast.internal.util.scheduler.EntryTaskScheduler
Cancel all scheduled executions with the given key.
cancel(K) - Method in class com.hazelcast.internal.util.scheduler.SecondsBasedEntryTaskScheduler
 
cancel(boolean) - Method in class com.hazelcast.scheduledexecutor.impl.DelegatingScheduledFutureStripper
 
cancel(String) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
cancel(boolean) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledFutureProxy
 
cancel(boolean) - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
Attempts to cancel further scheduling of this task.
cancel(boolean) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
cancel(boolean) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
cancel() - Method in class com.hazelcast.topic.impl.reliable.MessageRunner
 
CANCEL_BACKUP_OP - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
CANCEL_OP - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
cancelAll() - Method in interface com.hazelcast.internal.util.scheduler.EntryTaskScheduler
Cancel all scheduled executions
cancelAll() - Method in class com.hazelcast.internal.util.scheduler.SecondsBasedEntryTaskScheduler
 
cancelAll(UUID, Throwable) - Method in class com.hazelcast.spi.impl.operationparker.impl.WaitSet
 
cancelAll(String, Object, Throwable) - Method in class com.hazelcast.spi.impl.operationparker.impl.WaitSet
 
cancelEviction(String) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
cancelEvictionIfExists() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
 
cancelExecution() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
 
cancelIfExists(K, V) - Method in interface com.hazelcast.internal.util.scheduler.EntryTaskScheduler
Cancels the scheduled executions for the given key and value if present.
cancelIfExists(K, V) - Method in class com.hazelcast.internal.util.scheduler.SecondsBasedEntryTaskScheduler
 
CANCELLATION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
CANCELLATION - Static variable in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
 
CancellationOperation - Class in com.hazelcast.executor.impl.operations
 
CancellationOperation() - Constructor for class com.hazelcast.executor.impl.operations.CancellationOperation
 
CancellationOperation(UUID, boolean) - Constructor for class com.hazelcast.executor.impl.operations.CancellationOperation
 
cancelOperation(Address, long) - Method in interface com.hazelcast.internal.services.CanCancelOperations
Notifies this service that an operation was requested to be cancelled.
cancelParkedOperations(String, Object, Throwable) - Method in class com.hazelcast.spi.impl.operationparker.impl.OperationParkerImpl
 
cancelParkedOperations(String, Object, Throwable) - Method in interface com.hazelcast.spi.impl.operationparker.OperationParker
 
CancelTaskBackupOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
CancelTaskBackupOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.CancelTaskBackupOperation
 
CancelTaskBackupOperation(String, String) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.CancelTaskBackupOperation
 
CancelTaskOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
CancelTaskOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.CancelTaskOperation
 
CancelTaskOperation(ScheduledTaskHandler, boolean) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.CancelTaskOperation
 
cancelTtlEntry(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
cancelTtlEntry(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
candidate() - Method in class com.hazelcast.cp.internal.raft.impl.dto.PreVoteRequest
 
candidate() - Method in class com.hazelcast.cp.internal.raft.impl.dto.VoteRequest
 
CandidateClusterContext - Class in com.hazelcast.client.impl.clientside
Carries the information that is specific to one cluster
CandidateClusterContext(String, AddressProvider, DiscoveryService, ICredentialsFactory, SocketInterceptor, ChannelInitializerProvider) - Constructor for class com.hazelcast.client.impl.clientside.CandidateClusterContext
 
CandidateState - Class in com.hazelcast.cp.internal.raft.impl.state
Mutable state maintained by each candidate during pre-voting & voting phases
candidateState() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns the candidate state
canEqual(Object) - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
 
canEqual(Object) - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
 
canEqual(Object) - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
 
canEqual(Object) - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
 
canEqual(Object) - Method in class com.hazelcast.query.impl.predicates.InPredicate
 
canEqual(Object) - Method in class com.hazelcast.query.impl.predicates.LikePredicate
 
canEqual(Object) - Method in class com.hazelcast.query.impl.predicates.NotEqualPredicate
 
canEqual(Object) - Method in class com.hazelcast.query.impl.predicates.RegexPredicate
 
CANNOT_REPLICATE_EXCEPTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
CannotCreateRaftGroupException - Exception in com.hazelcast.cp.internal.exception
An internal exception thrown when a Raft group is attempted to be created with a Hazelcast node that is not an active CP member.
CannotCreateRaftGroupException(String) - Constructor for exception com.hazelcast.cp.internal.exception.CannotCreateRaftGroupException
 
CannotRemoveCPMemberException - Exception in com.hazelcast.cp.internal.exception
Thrown while a CP member is requested to be removed from CP Subsystem while there is an ongoing process for another member.
CannotRemoveCPMemberException(String) - Constructor for exception com.hazelcast.cp.internal.exception.CannotRemoveCPMemberException
 
CannotReplicateException - Exception in com.hazelcast.cp.exception
A CPSubsystemException which is thrown when an entry cannot be replicated, which can occur in one of the following cases: a member leaves the CP group CP group itself is terminated uncommitted entry count reaches to (see RaftAlgorithmConfig.getUncommittedEntryCountToRejectNewAppends()) a membership change is requested before an entry is committed on a term
CannotReplicateException(RaftEndpoint) - Constructor for exception com.hazelcast.cp.exception.CannotReplicateException
 
canonicalHostName - Variable in class com.hazelcast.internal.management.dto.ClientEndPointDTO
Client's FQDN if we're able to resolve it, host name if not.
canonicalizeAttribute(String) - Static method in class com.hazelcast.query.impl.IndexUtils
Produces canonical attribute representation by stripping an unnecessary "this." qualifier from the passed attribute, if any.
canonicalizeForHashLookup(Comparable) - Static method in class com.hazelcast.query.impl.Comparables
Canonicalizes the given Comparable value for the purpose of a hash-based lookup.
canonicalizeForHashLookup(Comparable) - Static method in class com.hazelcast.query.impl.Numbers
Canonicalizes the given Number value for the purpose of a hash-based lookup.
canonicalizeQueryArgumentScalar(Comparable) - Method in class com.hazelcast.query.impl.AbstractIndex
 
canonicalizeQueryArgumentScalar(Comparable) - Method in interface com.hazelcast.query.impl.IndexStore
Canonicalizes the given value for the purpose of a hash-based lookup.
canonicalizeQueryArgumentScalar(Comparable) - Method in interface com.hazelcast.query.impl.InternalIndex
Canonicalizes the given value for the purpose of a hash-based lookup.
canonicalizeQueryArgumentScalar(Comparable) - Method in class com.hazelcast.query.impl.OrderedIndexStore
 
canonicalizeQueryArgumentScalar(Comparable) - Method in class com.hazelcast.query.impl.UnorderedIndexStore
 
canonicalizeScalarForStorage(Comparable) - Method in class com.hazelcast.query.impl.OrderedIndexStore
 
canonicalizeScalarForStorage(Comparable) - Method in class com.hazelcast.query.impl.UnorderedIndexStore
 
CANONICALIZING_SET - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
CanonicalizingHashSet<E> - Class in com.hazelcast.aggregation.impl
A read-only hash set that canonicalizes its mixed-type numeric elements for lookup operations while still preserving the original element values.
CanonicalizingHashSet() - Constructor for class com.hazelcast.aggregation.impl.CanonicalizingHashSet
Constructs a new empty instance of canonicalizing hash set.
CanonicalizingHashSet(int) - Constructor for class com.hazelcast.aggregation.impl.CanonicalizingHashSet
Constructs a new empty instance of canonicalizing hash set with the given expected capacity.
canPrimaryDriveExpiration() - Method in class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
 
canQueryLinearizable() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Returns true if a new query is currently allowed to be executed without appending to the Raft log.
canReplicateNewEntry(Object) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Returns true if a new entry with the operation is currently allowed to be replicated.
canSendInvalidation(Invalidation) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.AbstractBaseNearCacheInvalidationListener
 
canTransformResource(String) - Method in class com.hazelcast.buildutils.HazelcastManifestTransformer
 
canUpdateStats(R) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
capacity - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddDurableExecutorConfigCodec.RequestParameters
capacity of executor tasks per partition
capacity - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddRingbufferConfigCodec.RequestParameters
capacity of the ringbuffer
capacity - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddScheduledExecutorConfigCodec.RequestParameters
maximum number of tasks that a scheduler can have at any given point in time per partition
capacity() - Method in class com.hazelcast.client.impl.proxy.ClientRingbufferProxy
 
capacity() - Method in class com.hazelcast.internal.util.collection.BiInt2ObjectMap
Get the total capacity for the map to which the load factor with be a fraction of.
capacity() - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
Get the total capacity for the map to which the load factor with be a fraction of.
capacity() - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
Get the total capacity for the map to which the load factor with be a fraction of.
capacity() - Method in class com.hazelcast.internal.util.collection.OAHashSet
Returns the capacity of the set
capacity() - Method in interface com.hazelcast.internal.util.concurrent.Pipe
Returns the number of items this pipe can hold at a time.
capacity() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray
 
capacity() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
capacity() - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
 
capacity() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Returns the capacity of this Ringbuffer.
CAPACITY_OFFSET - Static variable in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
CapacityUtil - Class in com.hazelcast.internal.util.hashslot.impl
Utility functions related to data structure capacity calculation.
CARDINALITY_EST_CONTAINER - Static variable in class com.hazelcast.cardinality.impl.CardinalityEstimatorDataSerializerHook
 
CARDINALITY_ESTIMATOR_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
CARDINALITY_ESTIMATOR_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
CARDINALITY_ESTIMATOR_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
CARDINALITY_ESTIMATOR_MERGING_ENTRY - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
CardinalityEstimator - Interface in com.hazelcast.cardinality
CardinalityEstimator is a redundant and highly available distributed data-structure used for probabilistic cardinality estimation purposes, on unique items, in significantly sized data cultures.
CardinalityEstimatorAddCodec - Class in com.hazelcast.client.impl.protocol.codec
Add a new hash in the estimation set.
CardinalityEstimatorAddCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CardinalityEstimatorAddCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CardinalityEstimatorAddMessageTask - Class in com.hazelcast.client.impl.protocol.task.cardinality
 
CardinalityEstimatorAddMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorAddMessageTask
 
CardinalityEstimatorBackupAwareOperation - Class in com.hazelcast.cardinality.impl.operations
 
CardinalityEstimatorBackupAwareOperation() - Constructor for class com.hazelcast.cardinality.impl.operations.CardinalityEstimatorBackupAwareOperation
 
CardinalityEstimatorBackupAwareOperation(String) - Constructor for class com.hazelcast.cardinality.impl.operations.CardinalityEstimatorBackupAwareOperation
 
CardinalityEstimatorConfig - Class in com.hazelcast.config
Configuration options for the CardinalityEstimator
CardinalityEstimatorConfig() - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
 
CardinalityEstimatorConfig(String) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
 
CardinalityEstimatorConfig(String, int, int) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
 
CardinalityEstimatorConfig(String, int, int, MergePolicyConfig) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
 
CardinalityEstimatorConfig(String, int, int, String, MergePolicyConfig) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
 
CardinalityEstimatorConfig(CardinalityEstimatorConfig) - Constructor for class com.hazelcast.config.CardinalityEstimatorConfig
 
CardinalityEstimatorConfigReadOnly - Class in com.hazelcast.internal.config
 
CardinalityEstimatorConfigReadOnly(CardinalityEstimatorConfig) - Constructor for class com.hazelcast.internal.config.CardinalityEstimatorConfigReadOnly
 
CardinalityEstimatorContainer - Class in com.hazelcast.cardinality.impl
 
CardinalityEstimatorContainer() - Constructor for class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
 
CardinalityEstimatorContainer(int, int) - Constructor for class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
 
CardinalityEstimatorDataSerializerHook - Class in com.hazelcast.cardinality.impl
 
CardinalityEstimatorDataSerializerHook() - Constructor for class com.hazelcast.cardinality.impl.CardinalityEstimatorDataSerializerHook
 
CardinalityEstimatorEstimateCodec - Class in com.hazelcast.client.impl.protocol.codec
Estimates the cardinality of the aggregation so far.
CardinalityEstimatorEstimateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CardinalityEstimatorEstimateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CardinalityEstimatorEstimateMessageTask - Class in com.hazelcast.client.impl.protocol.task.cardinality
 
CardinalityEstimatorEstimateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorEstimateMessageTask
 
CardinalityEstimatorMergingEntry - Class in com.hazelcast.spi.impl.merge
CardinalityEstimatorMergingEntry() - Constructor for class com.hazelcast.spi.impl.merge.CardinalityEstimatorMergingEntry
 
CardinalityEstimatorMergingEntry(SerializationService) - Constructor for class com.hazelcast.spi.impl.merge.CardinalityEstimatorMergingEntry
 
CardinalityEstimatorPermission - Class in com.hazelcast.security.permission
 
CardinalityEstimatorPermission(String, String...) - Constructor for class com.hazelcast.security.permission.CardinalityEstimatorPermission
 
CardinalityEstimatorProxy - Class in com.hazelcast.cardinality.impl
 
CardinalityEstimatorService - Class in com.hazelcast.cardinality.impl
 
CardinalityEstimatorService() - Constructor for class com.hazelcast.cardinality.impl.CardinalityEstimatorService
 
casCachedValue(Object, Object) - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
casCachedValue(Object, Object) - Method in interface com.hazelcast.map.impl.record.Record
Atomically sets the cached value to the given new value if the current cached value == the expected value.
casRecordState(long, long) - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
casRecordState(long, long) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecord
 
casSequence(long, long) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataContainer
 
casStaleSequence(long, long) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataContainer
 
casUuid(UUID, UUID) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataContainer
 
cause() - Method in interface com.hazelcast.internal.auditlog.AuditableEvent
Return an exception or error (if any) which caused this event.
cause(Throwable) - Method in interface com.hazelcast.internal.auditlog.EventBuilder
Sets error/exception which caused the event (if any).
cause(Throwable) - Method in class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService.Builder
 
cause() - Method in class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService.NoOpEvent
 
cd - Variable in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
CDL_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
CDL_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ChainingFuture<T> - Class in com.hazelcast.internal.util.futures
Iterates over supplied InternalCompletableFuture serially.
ChainingFuture(Iterator<InternalCompletableFuture<T>>, ChainingFuture.ExceptionHandler) - Constructor for class com.hazelcast.internal.util.futures.ChainingFuture
 
ChainingFuture.ExceptionHandler - Interface in com.hazelcast.internal.util.futures
 
CHANGE_CLUSTER_STATE - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
CHANGE_PERMITS_OP - Static variable in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreDataSerializerHook
 
changeClusterState(ClusterState) - Method in class com.hazelcast.client.impl.proxy.ClientClusterProxy
 
changeClusterState(ClusterState, TransactionOptions) - Method in class com.hazelcast.client.impl.proxy.ClientClusterProxy
 
changeClusterState(ClusterState) - Method in interface com.hazelcast.cluster.Cluster
Changes state of the cluster to the given state transactionally.
changeClusterState(ClusterState, TransactionOptions) - Method in interface com.hazelcast.cluster.Cluster
Changes state of the cluster to the given state transactionally.
changeClusterState(ClusterState) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
changeClusterState(ClusterState, TransactionOptions) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
ChangeClusterStateRequest - Class in com.hazelcast.internal.management.request
Request coming from Management Center for changing the ClusterState
ChangeClusterStateRequest() - Constructor for class com.hazelcast.internal.management.request.ChangeClusterStateRequest
 
ChangeClusterStateRequest(String) - Constructor for class com.hazelcast.internal.management.request.ChangeClusterStateRequest
 
changeClusterVersion(Version) - Method in class com.hazelcast.client.impl.proxy.ClientClusterProxy
 
changeClusterVersion(Version, TransactionOptions) - Method in class com.hazelcast.client.impl.proxy.ClientClusterProxy
 
changeClusterVersion(Version) - Method in interface com.hazelcast.cluster.Cluster
Changes the cluster version transactionally.
changeClusterVersion(Version, TransactionOptions) - Method in interface com.hazelcast.cluster.Cluster
Changes the cluster version transactionally, with the transaction options provided.
changeClusterVersion(Version) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
changeClusterVersion(Version, MemberMap) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
changeClusterVersion(Version, TransactionOptions) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
changeNodeStateToActive() - Method in class com.hazelcast.instance.impl.Node
 
changeNodeStateToPassive() - Method in class com.hazelcast.instance.impl.Node
 
changePermits(CPGroupId, long, String, SemaphoreEndpoint, UUID, int) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreService
 
ChangePermitsMessageTask - Class in com.hazelcast.cp.internal.datastructures.semaphore.client
Client message task for ChangePermitsOp
ChangePermitsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.client.ChangePermitsMessageTask
 
ChangePermitsOp - Class in com.hazelcast.cp.internal.datastructures.semaphore.operation
ChangePermitsOp() - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.operation.ChangePermitsOp
 
ChangePermitsOp(String, long, long, UUID, int) - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.operation.ChangePermitsOp
 
ChangeRaftGroupMembershipOp - Class in com.hazelcast.cp.internal.operation
Replicates a membership change operation to a Raft group.
ChangeRaftGroupMembershipOp() - Constructor for class com.hazelcast.cp.internal.operation.ChangeRaftGroupMembershipOp
 
ChangeRaftGroupMembershipOp(CPGroupId, long, RaftEndpoint, MembershipChangeMode) - Constructor for class com.hazelcast.cp.internal.operation.ChangeRaftGroupMembershipOp
 
ChangeWanStateOperation - Class in com.hazelcast.internal.management.operation
Stop, pause or resume WAN replication for the given wanReplicationName and wanPublisherId.
ChangeWanStateOperation(String, String, WanPublisherState) - Constructor for class com.hazelcast.internal.management.operation.ChangeWanStateOperation
 
ChangeWanStateRequest - Class in com.hazelcast.internal.management.request
Request coming from Management Center for ChangeWanStateOperation
ChangeWanStateRequest() - Constructor for class com.hazelcast.internal.management.request.ChangeWanStateRequest
 
ChangeWanStateRequest(String, String, WanPublisherState) - Constructor for class com.hazelcast.internal.management.request.ChangeWanStateRequest
 
Channel - Interface in com.hazelcast.internal.networking
A Channel is a construct that can send/receive like Packets/ClientMessages etc.
channel - Variable in class com.hazelcast.internal.networking.ChannelHandler
The Channel this ChannelHandler handles.
channel - Variable in class com.hazelcast.internal.networking.nio.NioPipeline
 
channelAdded(MigratablePipeline, MigratablePipeline) - Method in class com.hazelcast.internal.networking.nio.iobalancer.IOBalancer
 
ChannelCloseListener - Interface in com.hazelcast.internal.networking
A listener called when a Channel is closed.
ChannelErrorHandler - Interface in com.hazelcast.internal.networking
A strategy for controlling what needs to be done in case of an Exception being thrown when the Networking processes events.
ChannelHandler<H extends ChannelHandler,S,D> - Class in com.hazelcast.internal.networking
ChannelHandler is either responsible for processing inbound or outbound data.
ChannelHandler() - Constructor for class com.hazelcast.internal.networking.ChannelHandler
 
ChannelInitializer - Interface in com.hazelcast.internal.networking
Initializes the Channel when the Channel is used for the first time.
ChannelInitializerProvider - Interface in com.hazelcast.internal.networking
Initializes the Channel when the Channel is used for the first time.
ChannelOption<T> - Class in com.hazelcast.internal.networking
A ChannelOptions option for the ChannelOptions.
ChannelOption(String) - Constructor for class com.hazelcast.internal.networking.ChannelOption
Creates a ChannelOption with the provided name.
ChannelOptions - Interface in com.hazelcast.internal.networking
Contains the configuration of a Channel.
channelRemoved(MigratablePipeline, MigratablePipeline) - Method in class com.hazelcast.internal.networking.nio.iobalancer.IOBalancer
 
CHAR_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
CHAR_SIZE_IN_BYTES - Static variable in class com.hazelcast.internal.nio.Bits
Char size in bytes
CharArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.CharArraySerializer
 
CharSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.CharSerializer
 
check(YamlNode) - Static method in class com.hazelcast.internal.config.yaml.YamlDomChecker
Performs {code @null} checks on the provided YAML node recursively.
check(Node) - Method in class com.hazelcast.internal.util.PhoneHome
 
check2BytesAligned(long) - Static method in class com.hazelcast.internal.memory.impl.AlignmentUtil
 
check4BytesAligned(long) - Static method in class com.hazelcast.internal.memory.impl.AlignmentUtil
 
check8BytesAligned(long) - Static method in class com.hazelcast.internal.memory.impl.AlignmentUtil
 
CHECK_EVICT - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
CHECK_REPLICA_VERSION - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
checkAdvancedNetworkConfig(Config) - Static method in class com.hazelcast.internal.config.ConfigValidator
 
checkAllDone(Collection<Future>) - Static method in class com.hazelcast.internal.util.FutureUtil
Rethrow exeception of the fist future that completed with an exception
checkAndAddCapacityOrThrowException(int) - Method in class com.hazelcast.map.impl.mapstore.writebehind.NodeWideUsedCapacityCounter
Increments/decrements counter by adding supplied delta.
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
 
checkAndLogPropertyDeprecated(HazelcastProperties, HazelcastProperty) - Static method in class com.hazelcast.internal.config.ConfigValidator
Checks if given group property is defined within given Hazelcast properties.
checkAsyncBackupCount(int, int) - Static method in class com.hazelcast.internal.util.Preconditions
Tests if the newAsyncBackupCount count is valid.
checkAvailable() - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
checkAvailableCapacity(int) - Method in class com.hazelcast.cp.internal.raft.impl.log.RaftLog
Returns true if the Raft log contains empty indices for the requested amount
checkBackupCount(int, int) - Static method in class com.hazelcast.internal.util.Preconditions
Tests if the newBackupCount count is valid.
checkBasicConfig(C, SplitBrainMergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
Validates the given AbstractBasicConfig implementation.
checkBlockableReadSequence(long) - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
 
checkBlockableReadSequence(long) - Method in interface com.hazelcast.ringbuffer.impl.Ringbuffer
Check if the sequence can be read from the ringbuffer or if the sequence is of the next item to be added into the ringbuffer.
checkBlockableReadSequence(long) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
Check if the sequence is of an item that can be read immediately or is the sequence of the next item to be added into the ringbuffer.
checkCacheConfig(CacheSimpleConfig, SplitBrainMergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
Validates the given CacheSimpleConfig.
checkCacheConfig(CacheConfig, SplitBrainMergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
Validates the given CacheConfig.
checkCacheConfig(InMemoryFormat, EvictionConfig, String, SplitBrainMergeTypeProvider, SplitBrainMergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
Validates the given parameters in the context of an ICache config.
checkClassDefErrors - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
checkCollectionConfig(CollectionConfig, SplitBrainMergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
Validates the given CollectionConfig.
checkCPSubsystemConfig(CPSubsystemConfig) - Static method in class com.hazelcast.internal.config.ConfigValidator
 
checkDrainerGone() - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Checks whether the drainer thread has left and throws an exception if it has.
checkEvictable(RecordStore) - Method in class com.hazelcast.map.impl.eviction.EvictionChecker
 
checkEvictable(RecordStore) - Method in interface com.hazelcast.map.impl.eviction.Evictor
Check whether the supplied record-store needs eviction.
checkEvictable(RecordStore) - Method in class com.hazelcast.map.impl.eviction.EvictorImpl
 
checkEvictionConfig(EvictionConfig, boolean) - Static method in class com.hazelcast.internal.config.ConfigValidator
Checks if a EvictionConfig is valid in its context.
checkEvictionConfig(EvictionPolicy, String, Object, boolean) - Static method in class com.hazelcast.internal.config.ConfigValidator
Checks if parameters for an EvictionConfig are valid in their context.
checkFalse(boolean, String) - Static method in class com.hazelcast.internal.util.Preconditions
Tests whether the supplied expression is false.
checkHasNext(Iterator<T>, String) - Static method in class com.hazelcast.internal.util.Preconditions
Check if iterator has next element.
checkHasText(String, String) - Static method in class com.hazelcast.internal.util.Preconditions
Tests if a string contains text.
checkIfLoaded() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
checkIfLoaded() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
checkIndexNotNegative(int) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
checkInstanceOf(Class<E>, Object, String) - Static method in class com.hazelcast.internal.util.Preconditions
Tests whether the supplied object is an instance of the supplied class type.
checkInstanceOf(Class<E>, Object) - Static method in class com.hazelcast.internal.util.Preconditions
 
checkJavaInternalAccess(ILogger) - Static method in class com.hazelcast.internal.util.ModularJavaUtils
Prints warning to given ILogger if Hazelcast is not provided a sufficient access to Java internal packages on Java 9 and newer.
checkMapConfig(MapConfig, NativeMemoryConfig, SplitBrainMergePolicyProvider, HazelcastProperties) - Static method in class com.hazelcast.internal.config.ConfigValidator
Validates the given MapConfig.
checkMergePolicySupportsInMemoryFormat(String, Object, InMemoryFormat, boolean, ILogger) - Static method in class com.hazelcast.internal.config.MergePolicyValidator
Checks if the given InMemoryFormat can be merged by the given mergePolicy instance.
checkMetadataGroupInitSuccessful() - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
checkMultiMapConfig(MultiMapConfig, SplitBrainMergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
Validates the given MultiMapConfig.
checkNearCacheConfig(String, NearCacheConfig, NativeMemoryConfig, boolean) - Static method in class com.hazelcast.internal.config.ConfigValidator
Checks preconditions to create a map proxy with Near Cache.
checkNegative(long, String) - Static method in class com.hazelcast.internal.util.Preconditions
Tests if the value is < 0.
checkNoNullInside(Iterable<T>, String) - Static method in class com.hazelcast.internal.util.Preconditions
Tests if the elements inside the argument collection are not null.
checkNotInstanceOf(Class, E, String) - Static method in class com.hazelcast.internal.util.Preconditions
Tests the supplied object to see if it is not a type of the supplied class.
checkNotNegative(long, String) - Static method in class com.hazelcast.internal.util.Preconditions
Tests if the value is >= 0.
checkNotNegative(int, String) - Static method in class com.hazelcast.internal.util.Preconditions
Tests if the value is >= 0.
checkNotNull(T, String) - Static method in class com.hazelcast.internal.util.Preconditions
Tests if an argument is not null.
checkNotNull(T) - Static method in class com.hazelcast.internal.util.Preconditions
Tests if an argument is not null.
checkObjectNotNull(Object) - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
 
checkOrRepairSequence(int, long, boolean) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingHandler
Checks nextSequence against current one.
checkOrRepairUuid(int, UUID) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingHandler
 
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.internal.util.Preconditions
Tests if a value is positive, that is strictly larger than 0 (value > 0).
checkPositive(double, String) - Static method in class com.hazelcast.internal.util.Preconditions
Tests if a value is positive, that is strictly larger than 0 (value > 0).
checkPositive(int, String) - Static method in class com.hazelcast.internal.util.Preconditions
Tests if a value is positive, that is strictly larger than 0 (value > 0).
checkQueueConfig(QueueConfig, SplitBrainMergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
Validates the given QueueConfig.
checkReadSequence(long) - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
 
checkReadSequence(long) - Method in interface com.hazelcast.ringbuffer.impl.Ringbuffer
Check if the sequence can be read from the ringbuffer.
checkReferenceAligned(long) - Static method in class com.hazelcast.internal.memory.impl.AlignmentUtil
 
checkReplicatedMapConfig(ReplicatedMapConfig, SplitBrainMergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
Validates the given ReplicatedMapConfig.
CheckReplicaVersionOperation - Class in com.hazelcast.replicatedmap.impl.operation
Checks whether replica version is in sync with the primary.
CheckReplicaVersionOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.CheckReplicaVersionOperation
 
CheckReplicaVersionOperation(PartitionContainer) - Constructor for class com.hazelcast.replicatedmap.impl.operation.CheckReplicaVersionOperation
 
checkRingbufferConfig(RingbufferConfig, SplitBrainMergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
Validates the given RingbufferConfig.
checkScheduledExecutorConfig(ScheduledExecutorConfig, SplitBrainMergePolicyProvider) - Static method in class com.hazelcast.internal.config.ConfigValidator
Validates the given ScheduledExecutorConfig.
checkSerializable(Object, String) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
Checks that the object implements Serializable and is correctly serializable by actually trying to serialize it.
checkState(boolean, String) - Static method in class com.hazelcast.internal.util.Preconditions
Check the state of a condition
checkTransactionActive() - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
 
checkTrue(boolean, String) - Static method in class com.hazelcast.internal.util.Preconditions
Tests whether the supplied expression is true.
child(String) - Method in interface com.hazelcast.internal.yaml.YamlMapping
Gets a child node by its name
child(String) - Method in class com.hazelcast.internal.yaml.YamlMappingImpl
 
child(int) - Method in interface com.hazelcast.internal.yaml.YamlSequence
Gets a child node by its index
childAsMapping(String) - Method in interface com.hazelcast.internal.yaml.YamlMapping
Gets a child mapping node by its name
childAsMapping(String) - Method in class com.hazelcast.internal.yaml.YamlMappingImpl
 
childAsMapping(int) - Method in interface com.hazelcast.internal.yaml.YamlSequence
Gets a child mapping node by its index
childAsScalar(String) - Method in interface com.hazelcast.internal.yaml.YamlMapping
Gets a child scalar node by its name
childAsScalar(String) - Method in class com.hazelcast.internal.yaml.YamlMappingImpl
 
childAsScalar(int) - Method in interface com.hazelcast.internal.yaml.YamlSequence
Gets a child scalar node by its index
childAsScalarValue(String) - Method in interface com.hazelcast.internal.yaml.YamlMapping
Gets a child scalar node's value by its name
childAsScalarValue(String, Class<T>) - Method in interface com.hazelcast.internal.yaml.YamlMapping
Gets a child scalar node's value by its name with type hinting
childAsScalarValue(String) - Method in class com.hazelcast.internal.yaml.YamlMappingImpl
 
childAsScalarValue(String, Class<T>) - Method in class com.hazelcast.internal.yaml.YamlMappingImpl
 
childAsScalarValue(int) - Method in interface com.hazelcast.internal.yaml.YamlSequence
Gets a child scalar node's value by its index
childAsScalarValue(int, Class<T>) - Method in interface com.hazelcast.internal.yaml.YamlSequence
Gets a child scalar node's value by its name with type hinting
childAsSequence(String) - Method in interface com.hazelcast.internal.yaml.YamlMapping
Gets a child sequence node by its name
childAsSequence(String) - Method in class com.hazelcast.internal.yaml.YamlMappingImpl
 
childAsSequence(int) - Method in interface com.hazelcast.internal.yaml.YamlSequence
Gets a child sequence node by its index
childCount() - Method in interface com.hazelcast.internal.yaml.YamlCollection
Returns the number of the children that the collection has
childCount() - Method in class com.hazelcast.internal.yaml.YamlMappingImpl
 
childElements(Node) - Static method in class com.hazelcast.config.DomConfigHelper
 
childElementsWithName(Node, String) - Static method in class com.hazelcast.config.DomConfigHelper
 
childElementWithName(Node, String) - Static method in class com.hazelcast.config.DomConfigHelper
 
childNode() - Method in class com.hazelcast.internal.yaml.YamlNameNodePair
The YamlNode instance
children() - Method in interface com.hazelcast.internal.yaml.YamlCollection
Returns the children nodes
children() - Method in class com.hazelcast.internal.yaml.YamlMappingImpl
 
childrenPairs() - Method in interface com.hazelcast.internal.yaml.YamlMapping
Returns the children as YamlNameNodePairs
childrenPairs() - Method in class com.hazelcast.internal.yaml.YamlMappingImpl
 
CLASS_CAST - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
CLASS_DATA - Static variable in class com.hazelcast.internal.usercodedeployment.impl.UserCodeDeploymentSerializerHook
 
CLASS_DATA_FINDER_OP - Static variable in class com.hazelcast.internal.usercodedeployment.impl.UserCodeDeploymentSerializerHook
 
CLASS_NOT_FOUND - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
ClassBlacklistFilter - Class in com.hazelcast.internal.usercodedeployment.impl.filter
All classes match unless they are in the explicit blacklist
ClassBlacklistFilter(String...) - Constructor for class com.hazelcast.internal.usercodedeployment.impl.filter.ClassBlacklistFilter
 
ClassData - Class in com.hazelcast.internal.usercodedeployment.impl
Carries byte code of a class along with its inner classes.
ClassData() - Constructor for class com.hazelcast.internal.usercodedeployment.impl.ClassData
 
ClassDataFinderOperation - Class in com.hazelcast.internal.usercodedeployment.impl.operation
 
ClassDataFinderOperation(String) - Constructor for class com.hazelcast.internal.usercodedeployment.impl.operation.ClassDataFinderOperation
 
ClassDataFinderOperation() - Constructor for class com.hazelcast.internal.usercodedeployment.impl.operation.ClassDataFinderOperation
 
ClassDataProvider - Class in com.hazelcast.internal.usercodedeployment.impl
Provides ClassData to remote members.
ClassDataProvider(UserCodeDeploymentConfig.ProviderMode, ClassLoader, ConcurrentMap<String, ClassSource>, ConcurrentMap<String, ClassSource>, ILogger) - Constructor for class com.hazelcast.internal.usercodedeployment.impl.ClassDataProvider
 
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
IMPORTANT: It uses a default portableVersion (0) for non-versioned classes.
ClassDefinitionBuilder(int, int, int) - Constructor for class com.hazelcast.nio.serialization.ClassDefinitionBuilder
IMPORTANT: Make sure that the version matches the portableVersion in the SerializationService
ClassDefinitionImpl - Class in com.hazelcast.internal.serialization.impl
 
ClassDefinitionImpl(int, int, int) - Constructor for class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
 
classDefinitions - Variable in class com.hazelcast.client.impl.protocol.codec.ClientDeployClassesCodec.RequestParameters
list of class definitions
classDefinitions - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
ClassFilter - Class in com.hazelcast.config
Holds blacklist and whitelist configuration in java deserialization configuration.
ClassFilter() - Constructor for class com.hazelcast.config.ClassFilter
 
ClassFilter(ClassFilter) - Constructor for class com.hazelcast.config.ClassFilter
 
classIterator(Class<T>, String, ClassLoader) - Static method in class com.hazelcast.internal.util.ServiceLoader
 
classLoader - Variable in class com.hazelcast.config.AbstractCacheConfig
The ClassLoader to be used to resolve key & value types, if set
classLoader - Variable in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
classLoader - Variable in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
 
classLoader - Variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
classLoader - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
classLoader - Variable in class com.hazelcast.internal.util.executor.AbstractExecutorThreadFactory
 
ClassLoaderUtil - Class in com.hazelcast.internal.nio
Utility class to deal with class loaders.
ClassLoadingMetricSet - Class in com.hazelcast.internal.metrics.metricsets
A Metric set for exposing ClassLoadingMXBean metrics.
ClassLocator - Class in com.hazelcast.internal.usercodedeployment.impl
Provides classes to a local member.
ClassLocator(ConcurrentMap<String, ClassSource>, ConcurrentMap<String, ClassSource>, ClassLoader, Filter<String>, Filter<Member>, UserCodeDeploymentConfig.ClassCacheMode, NodeEngine) - Constructor for class com.hazelcast.internal.usercodedeployment.impl.ClassLocator
 
className - Variable in class com.hazelcast.config.AbstractWanPublisherConfig
 
className - Variable in class com.hazelcast.config.ListenerConfig
 
className - Variable in class com.hazelcast.config.PredicateConfig
 
className - Variable in class com.hazelcast.config.SecurityInterceptorConfig
 
classNameFilter - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
ClassNameFilter - Interface in com.hazelcast.nio.serialization
Allows to intercept class resolution during deserialization based on classname.
ClassNameFilterParser - Class in com.hazelcast.internal.usercodedeployment.impl.filter
 
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.
ClasspathYamlConfig - Class in com.hazelcast.config
A Config which is initialized by loading a YAML configuration file from the classpath.
ClasspathYamlConfig(String) - Constructor for class com.hazelcast.config.ClasspathYamlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClasspathYamlConfig(String, Properties) - Constructor for class com.hazelcast.config.ClasspathYamlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClasspathYamlConfig(ClassLoader, String) - Constructor for class com.hazelcast.config.ClasspathYamlConfig
Creates a config which is loaded from a classpath resource.
ClasspathYamlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.config.ClasspathYamlConfig
Creates a config which is loaded from a classpath resource.
ClassSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.ClassSerializer
 
ClassSource - Class in com.hazelcast.internal.usercodedeployment.impl
Classloader created on a local member to define a class from a bytecode loaded from a remote source.
ClassSource(ClassLoader, ClassLocator) - Constructor for class com.hazelcast.internal.usercodedeployment.impl.ClassSource
 
ClassWhitelistFilter - Class in com.hazelcast.internal.usercodedeployment.impl.filter
Only classes in the whitelist match.
ClassWhitelistFilter(String...) - Constructor for class com.hazelcast.internal.usercodedeployment.impl.filter.ClassWhitelistFilter
 
cleanNodeName(Node) - Static method in class com.hazelcast.config.DomConfigHelper
 
cleanup(ObjectNamespace, int) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
 
cleanup(ObjectNamespace, int) - Method in interface com.hazelcast.internal.journal.EventJournal
Cleans up the event journal by removing any expired items.
cleanup(ObjectNamespace, int) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
 
cleanup() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
 
cleanupOnDisconnect() - Method in class com.hazelcast.client.impl.spi.impl.ClientClusterServiceImpl
 
cleanupOnDisconnect() - Method in class com.hazelcast.client.impl.spi.impl.ClientPartitionServiceImpl
 
clear() - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
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.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.record.CacheRecordHashMap
 
clear() - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
clear() - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
clear() - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
clear() - Method in interface com.hazelcast.client.impl.ClientEndpointManager
Removes all endpoints.
clear() - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
 
clear() - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
clear() - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
clear() - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
clear() - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
clear() - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
clear() - Method in class com.hazelcast.client.impl.proxy.ClientSetProxy
 
clear() - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
clear() - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
clear(boolean) - 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() - 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
Removes all the PartitionGroupConfig.MemberGroupType instances.
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.cp.IAtomicReference
Clears the current stored reference.
clear() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
clear() - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
clear() - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
clear() - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
clear() - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
clear() - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
clear() - Method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
 
clear() - Method in class com.hazelcast.internal.dynamicconfig.AggregatingMap
 
clear() - Method in class com.hazelcast.internal.jmx.ListMBean
 
clear() - Method in class com.hazelcast.internal.jmx.MapMBean
 
clear() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
clear() - Method in class com.hazelcast.internal.jmx.QueueMBean
 
clear() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
clear() - Method in class com.hazelcast.internal.jmx.SetMBean
 
clear() - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
clear() - Method in class com.hazelcast.internal.metrics.managementcenter.ConcurrentArrayRingbuffer
 
clear() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
clear() - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
clear() - Method in interface com.hazelcast.internal.nearcache.NearCache
Removes all stored values.
clear() - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
Removes all stored values.
clear() - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
clear() - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
clear() - Method in class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolThreadLocal
 
clear() - Method in class com.hazelcast.internal.util.collection.ImmutableInflatableSet
 
clear() - Method in class com.hazelcast.internal.util.collection.ImmutablePartitionIdSet
 
clear() - Method in class com.hazelcast.internal.util.collection.InflatableSet
 
clear() - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
 
clear() - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap.KeySet
 
clear() - Method in class com.hazelcast.internal.util.collection.IntHashSet
 
clear() - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
 
clear() - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
 
clear() - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
 
clear() - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
 
clear() - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap.KeySet
 
clear() - Method in class com.hazelcast.internal.util.collection.LongHashSet
clear() - Method in interface com.hazelcast.internal.util.collection.LongSet
 
clear() - Method in class com.hazelcast.internal.util.collection.LongSetHsa
 
clear() - Method in class com.hazelcast.internal.util.collection.MapDelegatingSet
clear() - Method in class com.hazelcast.internal.util.collection.OAHashSet
 
clear() - Method in class com.hazelcast.internal.util.collection.PartitionIdSet
 
clear() - Method in class com.hazelcast.internal.util.concurrent.MPSCQueue
.
clear() - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
Removes all of the mappings from this map.
clear() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray
After this method returns, all slots in the current hash slot array are unassigned.
clear() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
clear() - Method in class com.hazelcast.internal.util.ItemCounter
Clears the counter.
clear() - Method in class com.hazelcast.internal.util.ResultSet
 
clear() - Method in interface com.hazelcast.map.IMap
Clears the map and deletes the items from the backing map store.
CLEAR - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
clear() - Method in class com.hazelcast.map.impl.MapEntries
 
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.proxy.MapProxyImpl
 
clear() - Method in class com.hazelcast.map.impl.query.QueryResultCollection
 
clear() - Method in interface com.hazelcast.map.impl.querycache.subscriber.InternalQueryCache
 
clear() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
clear() - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordStore
 
clear() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
clear() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Called by IMap.clear().
clear(boolean) - Method in interface com.hazelcast.map.impl.recordstore.Storage
 
clear(boolean) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
clear() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
CLEAR - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
clear() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
clear() - Method in interface com.hazelcast.multimap.MultiMap
Clears the multimap.
clear() - Method in class com.hazelcast.query.impl.AbstractIndex
 
clear() - Method in class com.hazelcast.query.impl.AttributeIndexRegistry
Clears this registry by unregistering all previously registered indexes.
clear() - Method in class com.hazelcast.query.impl.ConverterCache
Clears this cache by purging all entries.
clear() - Method in interface com.hazelcast.query.impl.Index
Clears out all entries from this index.
clear() - Method in class com.hazelcast.query.impl.IndexImpl
 
clear() - Method in interface com.hazelcast.query.impl.IndexStore
Clears the contents of this index by purging all its entries.
clear() - Method in class com.hazelcast.query.impl.OrderedIndexStore
 
clear() - Method in class com.hazelcast.query.impl.UnorderedIndexStore
 
CLEAR - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
clear() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
clear() - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
 
clear() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
clear() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
clear() - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
The clear operation wipes data out of the replicated maps.
clear() - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
 
clear() - Method in interface com.hazelcast.ringbuffer.impl.Ringbuffer
Clears the data in the ringbuffer.
clear() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
Clears the data in the ringbuffer.
clear() - Method in class com.hazelcast.spi.impl.operationservice.CallsPerMember
 
clear() - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
 
clear() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Clears the data in the ringbuffer.
clear() - Method in class com.hazelcast.spring.cache.HazelcastCache
 
clear() - Method in class com.hazelcast.wan.impl.merkletree.ArrayMerkleTree
 
clear() - Method in interface com.hazelcast.wan.impl.merkletree.MerkleTree
Clears the Merkle tree
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.map.impl.MapDataSerializerHook
 
CLEAR_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
CLEAR_FACTORY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CLEAR_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
CLEAR_OP_FACTORY - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
CLEAR_REMOTE_TX - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
CLEAR_REMOTE_TX_BACKUP - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
CLEAR_RESPONSE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
clearAll() - Method in class com.hazelcast.query.impl.Indexes
Clears contents of indexes managed by this instance.
clearAllListeners() - Method in interface com.hazelcast.client.impl.ClientEndpoint
 
clearAllListeners() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
clearAllNearCaches() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
 
clearAllNearCaches() - Method in interface com.hazelcast.internal.nearcache.NearCacheManager
Clears all defined NearCache instances.
clearAsync() - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
clearAsync() - Method in interface com.hazelcast.cp.IAtomicReference
Clears the current stored reference.
clearAsync() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
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.internal.nio.Bits
Clears n-th bit of the byte value
clearBit(int, int) - Static method in class com.hazelcast.internal.nio.Bits
Clears n-th bit of the integer value
clearClients() - Static method in class com.hazelcast.instance.impl.OutOfMemoryErrorDispatcher
 
clearCRDTState(Map<String, VectorClock>) - Method in interface com.hazelcast.internal.crdt.CRDTReplicationAwareService
Removes all of the CRDTs with vector clocks equal to the provided vector clocks.
clearCRDTState(Map<String, VectorClock>) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterService
 
clearExpiredRecordsTask - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
clearExpiredRecordsTask - Variable in class com.hazelcast.cache.impl.AbstractCacheService
 
ClearExpiredRecordsTask<T,S> - Class in com.hazelcast.internal.eviction
 
ClearExpiredRecordsTask(String, T[], HazelcastProperty, HazelcastProperty, HazelcastProperty, NodeEngine) - Constructor for class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
clearExpiredRecordsTask - Variable in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
ClearExpiredRecordsTask.ProcessablePartitionType - Enum in com.hazelcast.internal.eviction
Used when traversing partitions.
clearInternal() - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
clearInternal() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
clearListeners() - Method in class com.hazelcast.cache.impl.AbstractCacheSyncListenerCompleter
 
clearLoadedLoggers() - Method in class com.hazelcast.logging.LoggerFactorySupport
 
clearLockStore(int, ObjectNamespace) - Method in interface com.hazelcast.internal.locksupport.LockSupportService
 
clearLockStore(int, ObjectNamespace) - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
clearMigratingFlag(int) - Method in class com.hazelcast.internal.partition.impl.PartitionStateManager
 
clearNearCache(String) - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
 
clearNearCache(String) - Method in interface com.hazelcast.internal.nearcache.NearCacheManager
Clears NearCache instance associated with given name but not removes it.
ClearOperation - Class in com.hazelcast.collection.impl.queue.operations
Clears items stored by Queue.
ClearOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.ClearOperation
 
ClearOperation(String) - Constructor for class com.hazelcast.collection.impl.queue.operations.ClearOperation
 
ClearOperation - Class in com.hazelcast.map.impl.operation
 
ClearOperation() - Constructor for class com.hazelcast.map.impl.operation.ClearOperation
 
ClearOperation(String) - Constructor for class com.hazelcast.map.impl.operation.ClearOperation
 
ClearOperation - Class in com.hazelcast.multimap.impl.operations
 
ClearOperation() - Constructor for class com.hazelcast.multimap.impl.operations.ClearOperation
 
ClearOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.ClearOperation
 
ClearOperation - Class in com.hazelcast.replicatedmap.impl.operation
This operation will execute the remote clear on replicated map if ReplicatedMap.clear() is called.
ClearOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ClearOperation
 
ClearOperation(String, boolean) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ClearOperation
 
ClearOperation(String, boolean, long) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ClearOperation
 
ClearOperationFactory - Class in com.hazelcast.map.impl.operation
 
ClearOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.ClearOperationFactory
 
ClearOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.ClearOperationFactory
 
ClearOperationFactory - Class in com.hazelcast.replicatedmap.impl.operation
 
ClearOperationFactory() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ClearOperationFactory
 
ClearOperationFactory(String) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ClearOperationFactory
 
clearOtherDataThanStorage(boolean, boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
Only cleans the data other than storage-data that is held on this record store.
clearPartition(boolean, boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
clearPartition(boolean, boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Called by DistributedObject.destroy() or MapMigrationAwareService Clears internal partition data.
clearPartitionReplica(int) - Method in class com.hazelcast.cp.internal.datastructures.spi.AbstractCPMigrationAwareService
 
clearPartitionReplica(int) - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueService
 
clearPartitionReplica(int) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
clearPartitionReplica(int) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
clearPartitionReplicaVersions(int, ServiceNamespace) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
 
ClearRemoteTransactionBackupOperation - Class in com.hazelcast.transaction.impl.xa.operations
 
ClearRemoteTransactionBackupOperation() - Constructor for class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionBackupOperation
 
ClearRemoteTransactionBackupOperation(Data) - Constructor for class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionBackupOperation
 
ClearRemoteTransactionOperation - Class in com.hazelcast.transaction.impl.xa.operations
 
ClearRemoteTransactionOperation() - Constructor for class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
 
ClearRemoteTransactionOperation(Data) - Constructor for class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
 
clearReplicaSyncRequest(int, ServiceNamespace, int) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
Resets the state of the replica synchronization request for the given partition and replica.
clearRingBuffersHavingLesserBackupCountThan(int) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorPartitionContainer
 
clearServers() - Static method in class com.hazelcast.instance.impl.OutOfMemoryErrorDispatcher
 
clearWaitKeys() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.BlockingResource
 
ClearWanQueuesOperation - Class in com.hazelcast.internal.management.operation
Clear WAN replication queues for the given wan replication schema and publisher
ClearWanQueuesOperation(String, String) - Constructor for class com.hazelcast.internal.management.operation.ClearWanQueuesOperation
 
ClearWanQueuesRequest - Class in com.hazelcast.internal.management.request
Request coming from Management Center for ClearWanQueuesRequest
ClearWanQueuesRequest() - Constructor for class com.hazelcast.internal.management.request.ClearWanQueuesRequest
 
ClearWanQueuesRequest(String, String) - Constructor for class com.hazelcast.internal.management.request.ClearWanQueuesRequest
 
clearWithVersion(long) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
clearWithVersion(long) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
Client - Interface in com.hazelcast.client
The Client interface allows to get information about a connected client's socket address, type and UUID.
client - Variable in class com.hazelcast.client.impl.clientside.DefaultClientExtension
 
client - Variable in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
client - Variable in class com.hazelcast.client.impl.spi.impl.AbstractClientInvocationService
 
client - Variable in class com.hazelcast.client.impl.spi.impl.ClientClusterServiceImpl
 
client - Variable in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
CLIENT - Static variable in class com.hazelcast.instance.EndpointQualifier
 
CLIENT_BINARY_NEW - Static variable in class com.hazelcast.internal.nio.Protocols
New Client Protocol that is used for clients (Java, c++, c# client)
CLIENT_BLOCKING_EXECUTOR - Static variable in interface com.hazelcast.spi.impl.executionservice.ExecutionService
Name of the client transaction executor.
CLIENT_CLEANUP_PERIOD - Static variable in class com.hazelcast.spi.properties.GroupProperty
Time period to check if a client is still part of the cluster.
CLIENT_CLEANUP_TIMEOUT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Timeout duration to decide if a client is still part of the cluster.
CLIENT_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
CLIENT_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
CLIENT_ENGINE_BLOCKING_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
The number of threads that the client engine has available for processing requests that are blocking (example: related to transactions) When not set it is set as core-size * 20.
CLIENT_ENGINE_QUERY_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
The number of threads that the client engine has available for processing requests that are related to transactions When not set it is set as core-size.
CLIENT_ENGINE_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
The number of threads that the client engine has available for processing requests that are not partition specific.
CLIENT_ERROR - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
 
CLIENT_EXECUTOR - Static variable in interface com.hazelcast.spi.impl.executionservice.ExecutionService
Name of the client executor.
CLIENT_HEARTBEAT_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
CLIENT_MANAGEMENT_EXECUTOR - Static variable in interface com.hazelcast.spi.impl.executionservice.ExecutionService
Name of the client management executor.
CLIENT_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
CLIENT_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
CLIENT_PROTOCOL_UNVERIFIED_MESSAGE_BYTES - Static variable in class com.hazelcast.spi.properties.GroupProperty
Client protocol message size limit (in bytes) for unverified connections (i.e.
CLIENT_QUERY_EXECUTOR - Static variable in interface com.hazelcast.spi.impl.executionservice.ExecutionService
Name of the client executor.
CLIENT_TXN_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
CLIENT_TXN_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ClientAddDistributedObjectListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ClientAddDistributedObjectListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
ClientAddDistributedObjectListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientAddDistributedObjectListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientAddMembershipListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ClientAddMembershipListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
ClientAddMembershipListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientAddMembershipListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientAddPartitionListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ClientAddPartitionListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
ClientAddPartitionListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientAddPartitionListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientAddPartitionLostListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ClientAddPartitionLostListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
ClientAddPartitionLostListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientAddPartitionLostListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
clientAddressOf(Address) - Method in interface com.hazelcast.client.impl.ClientEngine
Locates the client address of the given member address.
clientAddressOf(Address) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
clientAddressOf(Address) - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
ClientAliasedDiscoveryConfigUtils - Class in com.hazelcast.client.config
Utility class for Aliased Discovery Configs in Hazelcast Client.
ClientAuthenticationCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ClientAuthenticationCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientAuthenticationCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientAuthenticationCustomCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ClientAuthenticationCustomCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientAuthenticationCustomCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientAwareService - Interface in com.hazelcast.internal.services
A interface that can be implemented by a SPI Service so that it can be notified about client disconnects.
clientAwareService - Variable in class com.hazelcast.map.impl.MapService
 
ClientBackupAwareResponse - Class in com.hazelcast.client.impl
Response of Invocations when client is backup aware Carries number of backups which will be delegated to clients
ClientBackupAwareResponse(int, Object) - Constructor for class com.hazelcast.client.impl.ClientBackupAwareResponse
 
ClientBwListConfigHandler - Class in com.hazelcast.internal.management
Handles client B/W list configuration received from Management Center and applies changes.
ClientBwListConfigHandler(ClientEngine) - Constructor for class com.hazelcast.internal.management.ClientBwListConfigHandler
 
ClientBwListDTO - Class in com.hazelcast.internal.management.dto
A serializable DTO that describes client B/W list filtering configuration received from Management Center.
ClientBwListDTO() - Constructor for class com.hazelcast.internal.management.dto.ClientBwListDTO
 
ClientBwListDTO(ClientBwListDTO.Mode, List<ClientBwListEntryDTO>) - Constructor for class com.hazelcast.internal.management.dto.ClientBwListDTO
 
ClientBwListDTO.Mode - Enum in com.hazelcast.internal.management.dto
 
ClientBwListEntryDTO - Class in com.hazelcast.internal.management.dto
A serializable DTO for client B/W list filtering configuration entries.
ClientBwListEntryDTO() - Constructor for class com.hazelcast.internal.management.dto.ClientBwListEntryDTO
 
ClientBwListEntryDTO(ClientBwListEntryDTO.Type, String) - Constructor for class com.hazelcast.internal.management.dto.ClientBwListEntryDTO
 
ClientBwListEntryDTO.Type - Enum in com.hazelcast.internal.management.dto
 
ClientCacheInvalidationMetaDataFetcher - Class in com.hazelcast.client.cache.impl.nearcache.invalidation
InvalidationMetaDataFetcher for client side usage
ClientCacheInvalidationMetaDataFetcher(ClientContext) - Constructor for class com.hazelcast.client.cache.impl.nearcache.invalidation.ClientCacheInvalidationMetaDataFetcher
 
ClientCachePartitionIterator<K,V> - Class in com.hazelcast.client.cache.impl
 
ClientCachePartitionIterator(ICacheInternal<K, V>, ClientContext, int, int, boolean) - Constructor for class com.hazelcast.client.cache.impl.ClientCachePartitionIterator
 
ClientCacheProxy<K,V> - Class in com.hazelcast.client.cache.impl
ICache implementation for Hazelcast clients.
ClientCacheProxyFactory - Class in com.hazelcast.client.cache.impl
 
ClientCacheProxyFactory(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.cache.impl.ClientCacheProxyFactory
 
ClientCacheStatisticsImpl - Class in com.hazelcast.client.cache.impl
CacheStatistics implementation for client side ICache.
ClientCacheStatisticsImpl(long) - Constructor for class com.hazelcast.client.cache.impl.ClientCacheStatisticsImpl
 
ClientCardinalityEstimatorProxy - Class in com.hazelcast.client.impl.proxy
Proxy implementation of CardinalityEstimator.
ClientCardinalityEstimatorProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.impl.proxy.ClientCardinalityEstimatorProxy
 
ClientChannelInitializer - Class in com.hazelcast.internal.nio.tcp
 
ClientClasspathXmlConfig - Class in com.hazelcast.client.config
A ClientConfig which is initialized by loading an XML configuration file from the classpath.
ClientClasspathXmlConfig(String) - Constructor for class com.hazelcast.client.config.ClientClasspathXmlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClientClasspathXmlConfig(String, Properties) - Constructor for class com.hazelcast.client.config.ClientClasspathXmlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClientClasspathXmlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.client.config.ClientClasspathXmlConfig
Creates a config which is loaded from a classpath resource.
ClientClasspathYamlConfig - Class in com.hazelcast.client.config
A ClientConfig which is initialized by loading an YAML configuration file from the classpath.
ClientClasspathYamlConfig(String) - Constructor for class com.hazelcast.client.config.ClientClasspathYamlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClientClasspathYamlConfig(String, Properties) - Constructor for class com.hazelcast.client.config.ClientClasspathYamlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClientClasspathYamlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.client.config.ClientClasspathYamlConfig
Creates a config which is loaded from a classpath resource.
ClientCloudConfig - Class in com.hazelcast.client.config
hazelcast.cloud configuration to let the client connect the cluster via hazelcast.cloud
ClientCloudConfig() - Constructor for class com.hazelcast.client.config.ClientCloudConfig
 
ClientCloudConfig(ClientCloudConfig) - Constructor for class com.hazelcast.client.config.ClientCloudConfig
 
ClientClusterProxy - Class in com.hazelcast.client.impl.proxy
Client implementation of the Cluster.
ClientClusterProxy(ClientClusterServiceImpl) - Constructor for class com.hazelcast.client.impl.proxy.ClientClusterProxy
 
ClientClusterService - Interface in com.hazelcast.client.impl.spi
Cluster service for Hazelcast clients.
ClientClusterServiceImpl - Class in com.hazelcast.client.impl.spi.impl
The ClientClusterService implementation.
ClientClusterServiceImpl(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.impl.spi.impl.ClientClusterServiceImpl
 
ClientClusterWideIterator<K,V> - Class in com.hazelcast.client.cache.impl
Client side cluster-wide iterator for ICache.
ClientClusterWideIterator(ICacheInternal<K, V>, ClientContext, boolean) - Constructor for class com.hazelcast.client.cache.impl.ClientClusterWideIterator
 
ClientClusterWideIterator(ICacheInternal<K, V>, ClientContext, int, boolean) - Constructor for class com.hazelcast.client.cache.impl.ClientClusterWideIterator
 
ClientClusterWideIterator(ICacheInternal<K, V>, ClientContext, int, int, boolean) - Constructor for class com.hazelcast.client.cache.impl.ClientClusterWideIterator
 
ClientConfig - Class in com.hazelcast.client.config
Main configuration to setup a Hazelcast Client
ClientConfig() - Constructor for class com.hazelcast.client.config.ClientConfig
 
ClientConfig(ClientConfig) - Constructor for class com.hazelcast.client.config.ClientConfig
 
ClientConfigXmlGenerator - Class in com.hazelcast.client.config
The ClientConfigXmlGenerator is responsible for transforming a ClientConfig to a Hazelcast Client XML string.
clientConnected(Client) - Method in interface com.hazelcast.client.ClientListener
Invoked when a client is connected.
ClientConnection - Class in com.hazelcast.client.impl.connection.nio
Client implementation of Connection.
ClientConnection(HazelcastClientInstanceImpl, int, Channel) - Constructor for class com.hazelcast.client.impl.connection.nio.ClientConnection
 
ClientConnection(HazelcastClientInstanceImpl, int) - Constructor for class com.hazelcast.client.impl.connection.nio.ClientConnection
 
clientConnectionCount - Variable in class com.hazelcast.internal.management.dto.ConnectionManagerDTO
 
ClientConnectionManager - Interface in com.hazelcast.client.impl.connection
Responsible for managing ClientConnection objects.
ClientConnectionManagerFactory - Interface in com.hazelcast.client.impl.clientside
 
ClientConnectionManagerImpl - Class in com.hazelcast.client.impl.connection.nio
Implementation of ClientConnectionManager.
ClientConnectionManagerImpl(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
ClientConnectionStrategy - Class in com.hazelcast.client.impl.connection
An abstract class called from ClientConnectionManager to customize how client connect to cluster, and provide various behaviours like async start or restart.
ClientConnectionStrategy() - Constructor for class com.hazelcast.client.impl.connection.ClientConnectionStrategy
 
ClientConnectionStrategyConfig - Class in com.hazelcast.client.config
Client connection strategy configuration is used for setting custom strategies and configuring strategy parameters.
ClientConnectionStrategyConfig() - Constructor for class com.hazelcast.client.config.ClientConnectionStrategyConfig
 
ClientConnectionStrategyConfig(ClientConnectionStrategyConfig) - Constructor for class com.hazelcast.client.config.ClientConnectionStrategyConfig
 
clientConnectionStrategyConfig - Variable in class com.hazelcast.client.impl.connection.ClientConnectionStrategy
 
ClientConnectionStrategyConfig.ReconnectMode - Enum in com.hazelcast.client.config
Reconnect options.
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 - Variable in class com.hazelcast.client.impl.connection.ClientConnectionStrategy
 
ClientContext - Class in com.hazelcast.client.impl.spi
Context holding all the required services, managers and the configuration for a Hazelcast client.
ClientContext(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.impl.spi.ClientContext
 
ClientCreateProxiesCodec - Class in com.hazelcast.client.impl.protocol.codec
Proxies will be created on all cluster members.
ClientCreateProxiesCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientCreateProxiesCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientCreateProxyCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ClientCreateProxyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientCreateProxyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientDataSerializerHook - Class in com.hazelcast.client.impl
 
ClientDataSerializerHook() - Constructor for class com.hazelcast.client.impl.ClientDataSerializerHook
 
ClientDelegatingFuture<V> - Class in com.hazelcast.client.impl
The Client Delegating Future is used to delegate ClientInvocationFuture to a user type to be used with further computation stages or get().
ClientDelegatingFuture(ClientInvocationFuture, SerializationService, ClientMessageDecoder, V, boolean) - Constructor for class com.hazelcast.client.impl.ClientDelegatingFuture
 
ClientDelegatingFuture(ClientInvocationFuture, SerializationService, ClientMessageDecoder, V) - Constructor for class com.hazelcast.client.impl.ClientDelegatingFuture
 
ClientDelegatingFuture(ClientInvocationFuture, SerializationService, ClientMessageDecoder) - Constructor for class com.hazelcast.client.impl.ClientDelegatingFuture
 
ClientDelegatingFuture(ClientInvocationFuture, SerializationService, ClientMessageDecoder, boolean) - Constructor for class com.hazelcast.client.impl.ClientDelegatingFuture
 
ClientDeployClassesCodec - Class in com.hazelcast.client.impl.protocol.codec
Deploys the list of classes to cluster Each item is a Map.Entry in the list.
ClientDeployClassesCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientDeployClassesCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientDestroyProxyCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ClientDestroyProxyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientDestroyProxyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
clientDisconnected(Client) - Method in interface com.hazelcast.client.ClientListener
Invoked when a client is disconnected.
clientDisconnected(UUID) - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
clientDisconnected(UUID) - Method in interface com.hazelcast.internal.services.ClientAwareService
Invoked when a client disconnects from a member.
clientDisconnected(UUID) - Method in class com.hazelcast.map.impl.MapService
 
clientDisconnected(UUID) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
ClientDiscoveryService - Class in com.hazelcast.client.impl.clientside
 
ClientDiscoveryService(int, ArrayList<CandidateClusterContext>) - Constructor for class com.hazelcast.client.impl.clientside.ClientDiscoveryService
 
ClientDurableExecutorServiceProxy - Class in com.hazelcast.client.impl.proxy
Proxy implementation of DurableExecutorService.
ClientDurableExecutorServiceProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
ClientDynamicClusterConfig - Class in com.hazelcast.client.impl.clientside
Client implementation of member side config.
ClientDynamicClusterConfig(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
ClientEndpoint - Interface in com.hazelcast.client.impl
Represents an endpoint to a client.
ClientEndPointDTO - Class in com.hazelcast.internal.management.dto
A Serializable DTO for ClientEndpoint.
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
The ClientEndpoint and Client implementation.
ClientEndpointImpl(ClientEngine, NodeEngineImpl, Connection) - Constructor for class com.hazelcast.client.impl.ClientEndpointImpl
 
ClientEndpointManager - Interface in com.hazelcast.client.impl
A manager for ClientEndpoints.
ClientEndpointManagerImpl - Class in com.hazelcast.client.impl
Manages and stores ClientEndpointImpls.
ClientEndpointManagerImpl(NodeEngine) - Constructor for class com.hazelcast.client.impl.ClientEndpointManagerImpl
 
ClientEngine - Interface in com.hazelcast.client.impl
The client Engine.
clientEngine - Variable in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
clientEngine - Variable in class com.hazelcast.instance.impl.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.internal.jmx
Management bean for ClientEngine
ClientEngineMBean(HazelcastInstance, ClientEngine, ManagementService) - Constructor for class com.hazelcast.internal.jmx.ClientEngineMBean
 
ClientEvent - Class in com.hazelcast.client.impl
Event used for notification of client connection and disconnection
ClientEvent(UUID, ClientEventType, InetSocketAddress, ClientType, String, Set<String>) - Constructor for class com.hazelcast.client.impl.ClientEvent
 
ClientEventRegistration - Class in com.hazelcast.client.impl.spi.impl.listener
Keeps the information related to to an event registration made by clients.
ClientEventRegistration(UUID, long, Connection, ListenerMessageCodec) - Constructor for class com.hazelcast.client.impl.spi.impl.listener.ClientEventRegistration
 
ClientEventType - Enum in com.hazelcast.client.impl
Event type used for client connection and disconnect events
ClientExceptionFactory - Class in com.hazelcast.client.impl.clientside
This class has the error codes and means of 1) creating exception from error code 2) getting the error code of given exception
ClientExceptionFactory(boolean) - Constructor for class com.hazelcast.client.impl.clientside.ClientExceptionFactory
 
ClientExceptionFactory.ExceptionFactory - Interface in com.hazelcast.client.impl.clientside
 
ClientExceptions - Class in com.hazelcast.client.impl.protocol
This class has the error codes and means of 1) creating exception from error code 2) getting the error code of given exception
ClientExceptions(boolean) - Constructor for class com.hazelcast.client.impl.protocol.ClientExceptions
 
ClientExecutionService - Interface in com.hazelcast.client.impl.spi
Executor service for Hazelcast clients.
ClientExecutionServiceImpl - Class in com.hazelcast.client.impl.spi.impl
 
ClientExecutionServiceImpl(String, ClassLoader, HazelcastProperties, int, LoggingService) - Constructor for class com.hazelcast.client.impl.spi.impl.ClientExecutionServiceImpl
 
ClientExecutorServiceProxy - Class in com.hazelcast.client.impl.proxy
 
ClientExecutorServiceProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
ClientExtension - Interface in com.hazelcast.client.impl
ClientExtension is a client extension mechanism to be able to plug different implementations of some modules, like; InternalSerializationService etc.
ClientFailoverClasspathXmlConfig - Class in com.hazelcast.client.config
A ClientFailoverConfig which is initialized by loading an XML configuration file from the classpath.
ClientFailoverClasspathXmlConfig(String) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathXmlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClientFailoverClasspathXmlConfig(String, Properties) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathXmlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClientFailoverClasspathXmlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathXmlConfig
Creates a config which is loaded from a classpath resource.
ClientFailoverClasspathYamlConfig - Class in com.hazelcast.client.config
A ClientFailoverConfig which is initialized by loading a YAML configuration file from the classpath.
ClientFailoverClasspathYamlConfig(String) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathYamlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClientFailoverClasspathYamlConfig(String, Properties) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathYamlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread() contextClassLoader.
ClientFailoverClasspathYamlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.client.config.ClientFailoverClasspathYamlConfig
Creates a config which is loaded from a classpath resource.
ClientFailoverConfig - Class in com.hazelcast.client.config
Config class to configure multiple client configs to be used by single client instance The client will try to connect them in given order.
ClientFailoverConfig() - Constructor for class com.hazelcast.client.config.ClientFailoverConfig
 
ClientFlakeIdGeneratorConfig - Class in com.hazelcast.client.config
The ClientFlakeIdGeneratorConfig contains the configuration for the client regarding Flake ID Generator.
ClientFlakeIdGeneratorConfig(String) - Constructor for class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
 
ClientFlakeIdGeneratorConfig(ClientFlakeIdGeneratorConfig) - Constructor for class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
Copy-constructor
ClientFlakeIdGeneratorProxy - Class in com.hazelcast.client.impl.proxy
Proxy implementation of FlakeIdGenerator.
ClientFlakeIdGeneratorProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.impl.proxy.ClientFlakeIdGeneratorProxy
 
ClientGetDistributedObjectsCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ClientGetDistributedObjectsCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientGetDistributedObjectsCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientGetPartitionsCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ClientGetPartitionsCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientGetPartitionsCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
clientHazelcastVersion - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec.RequestParameters
The Hazelcast version of the client.
clientHazelcastVersion - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec.RequestParameters
The Hazelcast version of the client.
ClientHeartbeatMonitor - Class in com.hazelcast.client.impl
Monitors client heartbeats..
ClientHeartbeatMonitor(ClientEndpointManager, ILogger, ExecutionService, HazelcastProperties) - Constructor for class com.hazelcast.client.impl.ClientHeartbeatMonitor
 
ClientICacheManager - Class in com.hazelcast.client.impl.clientside
Hazelcast instance cache manager provides a means to obtain JCache caches via HazelcastInstance API.
ClientICMPManager - Class in com.hazelcast.client.impl.connection.nio
Client icmp based ping manager Responsible for configuration handling and scheduling related tasks
ClientICMPManager(ClientIcmpPingConfig, ClientExecutionServiceImpl, LoggingService, ClientConnectionManagerImpl, HeartbeatManager) - Constructor for class com.hazelcast.client.impl.connection.nio.ClientICMPManager
 
ClientIcmpPingConfig - Class in com.hazelcast.client.config
Configuration for icmp ping failure detector of clients.
ClientIcmpPingConfig() - Constructor for class com.hazelcast.client.config.ClientIcmpPingConfig
 
ClientIcmpPingConfig(ClientIcmpPingConfig) - Constructor for class com.hazelcast.client.config.ClientIcmpPingConfig
 
ClientImpl - Class in com.hazelcast.client.impl
Default Client implementation.
ClientImpl(UUID, InetSocketAddress, String, Set<String>) - Constructor for class com.hazelcast.client.impl.ClientImpl
 
ClientInterceptingDelegatingFuture<V> - Class in com.hazelcast.client.impl
ClientInterceptingDelegatingFuture(ClientInvocationFuture, SerializationService, ClientMessageDecoder, BiConsumer<V, Throwable>) - Constructor for class com.hazelcast.client.impl.ClientInterceptingDelegatingFuture
 
ClientInvocation - Class in com.hazelcast.client.impl.spi.impl
Handles the routing of a request from a Hazelcast client.
ClientInvocation(HazelcastClientInstanceImpl, ClientMessage, Object, int, Address, Connection) - Constructor for class com.hazelcast.client.impl.spi.impl.ClientInvocation
 
ClientInvocation(HazelcastClientInstanceImpl, ClientMessage, Object) - Constructor for class com.hazelcast.client.impl.spi.impl.ClientInvocation
Create an invocation that will be executed on random member.
ClientInvocation(HazelcastClientInstanceImpl, ClientMessage, Object, int) - Constructor for class com.hazelcast.client.impl.spi.impl.ClientInvocation
Create an invocation that will be executed on owner of partitionId.
ClientInvocation(HazelcastClientInstanceImpl, ClientMessage, Object, Address) - Constructor for class com.hazelcast.client.impl.spi.impl.ClientInvocation
Create an invocation that will be executed on member with given address.
ClientInvocation(HazelcastClientInstanceImpl, ClientMessage, Object, Connection) - Constructor for class com.hazelcast.client.impl.spi.impl.ClientInvocation
Create an invocation that will be executed on given connection.
ClientInvocationFuture - Class in com.hazelcast.client.impl.spi.impl
 
ClientInvocationFuture(ClientInvocation, ClientMessage, ILogger, CallIdSequence) - Constructor for class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
ClientInvocationService - Interface in com.hazelcast.client.impl.spi
Invocation service for Hazelcast clients.
ClientInvokerWrapper - Class in com.hazelcast.client.impl.querycache.subscriber
Invocation functionality for client-side QueryCacheContext.
ClientInvokerWrapper(QueryCacheContext, HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.impl.querycache.subscriber.ClientInvokerWrapper
 
ClientIsFailoverSupportedCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ClientIsFailoverSupportedCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientIsFailoverSupportedCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientLifecycleMonitor - Class in com.hazelcast.client.impl
Monitors client connections across cluster.
ClientListener - Interface in com.hazelcast.client
The ClientListener provides the ability to listen to clients connecting and disconnecting from the member.
ClientListenerService - Interface in com.hazelcast.client.impl.spi
Client service to add/remove remote listeners.
ClientListProxy<E> - Class in com.hazelcast.client.impl.proxy
Proxy implementation of IList.
ClientListProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.impl.proxy.ClientListProxy
 
ClientLocalBackupListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds listener for backup acks
ClientLocalBackupListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
ClientLocalBackupListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientLocalBackupListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientLockReferenceIdGenerator - Class in com.hazelcast.client.impl.clientside
This class generates unique (per client) incrementing reference ID which is used during locking related requests.
ClientLockReferenceIdGenerator() - Constructor for class com.hazelcast.client.impl.clientside.ClientLockReferenceIdGenerator
 
ClientLoggingService - Class in com.hazelcast.client.impl.clientside
 
ClientLoggingService(String, String, BuildInfo, String) - Constructor for class com.hazelcast.client.impl.clientside.ClientLoggingService
 
ClientLongRegisterProxy - Class in com.hazelcast.internal.longregister.client
Proxy implementation of IAtomicLong.
ClientLongRegisterProxy(String, String, ClientContext) - Constructor for class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
ClientMapInvalidationMetaDataFetcher - Class in com.hazelcast.client.map.impl.nearcache.invalidation
InvalidationMetaDataFetcher for client side usage
ClientMapInvalidationMetaDataFetcher(ClientContext) - Constructor for class com.hazelcast.client.map.impl.nearcache.invalidation.ClientMapInvalidationMetaDataFetcher
 
ClientMapPartitionIterator<K,V> - Class in com.hazelcast.client.map.impl
Iterator for iterating map entries in the partitionId.
ClientMapPartitionIterator(ClientMapProxy<K, V>, ClientContext, int, int, boolean) - Constructor for class com.hazelcast.client.map.impl.ClientMapPartitionIterator
 
ClientMapProxy<K,V> - Class in com.hazelcast.client.impl.proxy
Proxy implementation of IMap.
ClientMapProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.impl.proxy.ClientMapProxy
 
ClientMapQueryPartitionIterator<K,V,R> - Class in com.hazelcast.client.map.impl
Iterator for iterating map entries in the partitionId.
ClientMapQueryPartitionIterator(ClientMapProxy<K, V>, ClientContext, int, int, Predicate<K, V>, Projection<? super Map.Entry<K, V>, R>) - Constructor for class com.hazelcast.client.map.impl.ClientMapQueryPartitionIterator
 
ClientMessage - Class in com.hazelcast.client.impl.protocol
Client Message is the carrier framed data as defined below.
clientMessage - Variable in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
ClientMessage.ForwardFrameIterator - Class in com.hazelcast.client.impl.protocol
 
ClientMessage.Frame - Class in com.hazelcast.client.impl.protocol
 
ClientMessageDecoder<T> - Interface in com.hazelcast.client.impl.clientside
Interface to pass specific decode methods to generic data structures that is dealing with client message
ClientMessageDecoder - Class in com.hazelcast.client.impl.protocol.util
Builds ClientMessages from byte chunks.
ClientMessageDecoder(Connection, Consumer<ClientMessage>, HazelcastProperties) - Constructor for class com.hazelcast.client.impl.protocol.util.ClientMessageDecoder
 
ClientMessageEncoder - Class in com.hazelcast.client.impl.protocol.util
A OutboundHandler for the new-client.
ClientMessageEncoder() - Constructor for class com.hazelcast.client.impl.protocol.util.ClientMessageEncoder
 
ClientMessageReader - Class in com.hazelcast.client.impl.protocol
 
ClientMessageReader(int) - Constructor for class com.hazelcast.client.impl.protocol.ClientMessageReader
 
ClientMessageSplitter - Class in com.hazelcast.client.impl.protocol.util
 
ClientMessageWriter - Class in com.hazelcast.client.impl.protocol
 
ClientMessageWriter() - Constructor for class com.hazelcast.client.impl.protocol.ClientMessageWriter
 
ClientMultiMapProxy<K,V> - Class in com.hazelcast.client.impl.proxy
Proxy implementation of MultiMap.
ClientMultiMapProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
clientName - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec.RequestParameters
the name of the client instance
clientName - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec.RequestParameters
the name of the client instance
clientName - Variable in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
 
ClientNetworkConfig - Class in com.hazelcast.client.config
Contains configuration parameters for client network related behaviour
ClientNetworkConfig() - Constructor for class com.hazelcast.client.config.ClientNetworkConfig
 
ClientNetworkConfig(ClientNetworkConfig) - Constructor for class com.hazelcast.client.config.ClientNetworkConfig
 
ClientNotAllowedInClusterException - Exception in com.hazelcast.client
A HazelcastException that is thrown when client can not use this cluster.
ClientNotAllowedInClusterException(String) - Constructor for exception com.hazelcast.client.ClientNotAllowedInClusterException
Creates a AuthenticationException with the given message.
ClientOutOfMemoryHandler - Class in com.hazelcast.client
To clear resources of the client upon OutOfMemory
ClientOutOfMemoryHandler() - Constructor for class com.hazelcast.client.ClientOutOfMemoryHandler
 
ClientPartitionListenerService - Class in com.hazelcast.client.impl
 
ClientPartitionService - Interface in com.hazelcast.client.impl.spi
Partition service for Hazelcast clients.
ClientPartitionServiceImpl - Class in com.hazelcast.client.impl.spi.impl
The ClientPartitionService implementation.
ClientPartitionServiceImpl(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.impl.spi.impl.ClientPartitionServiceImpl
 
ClientPingCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ClientPingCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientPingCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientPlainChannelInitializer - Class in com.hazelcast.client.impl.connection.nio
Client side ChannelInitializer for connections without SSL/TLS.
ClientPlainChannelInitializer(SocketOptions, boolean) - Constructor for class com.hazelcast.client.impl.connection.nio.ClientPlainChannelInitializer
 
ClientPNCounterProxy - Class in com.hazelcast.client.impl.proxy
Client proxy implementation for a PNCounter.
ClientPNCounterProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.impl.proxy.ClientPNCounterProxy
Creates a client PNCounter proxy
ClientProperty - Class in com.hazelcast.client.properties
Defines the name and default value for Hazelcast Client properties.
ClientProtocolEncoder - Class in com.hazelcast.client.impl.connection.nio
A OutboundHandler that writes the client protocol bytes and once they have been fully written, it removes itself from pipeline.
ClientProtocolEncoder() - Constructor for class com.hazelcast.client.impl.connection.nio.ClientProtocolEncoder
 
ClientProtocolErrorCodes - Class in com.hazelcast.client.impl.protocol
Each exception that are defined in client protocol have unique identifier which are error code.
ClientProxy - Class in com.hazelcast.client.impl.spi
Base class for client proxies.
ClientProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.impl.spi.ClientProxy
 
ClientProxyDescriptor - Interface in com.hazelcast.client.impl.spi
Descriptor of Hazelcast client proxies Provided by corresponding provider (see ClientProxyDescriptorProvider).
ClientProxyDescriptorProvider - Interface in com.hazelcast.client.impl.spi
It will be discovered from some external source (like META-INF/services) and registered in the system.
ClientProxyFactory - Interface in com.hazelcast.client.impl.spi
Factory interface creating client proxies.
ClientProxySessionManager - Class in com.hazelcast.client.cp.internal.session
Client-side implementation of Raft proxy session manager
ClientProxySessionManager(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.cp.internal.session.ClientProxySessionManager
 
ClientQueryCacheConfigurator - Class in com.hazelcast.client.impl.querycache.subscriber
Client side implementation of QueryCacheConfigurator.
ClientQueryCacheConfigurator(ClientConfig, QueryCacheEventService) - Constructor for class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheConfigurator
 
ClientQueryCacheContext - Class in com.hazelcast.client.impl.querycache
Client side implementation of QueryCacheContext.
ClientQueryCacheContext(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.impl.querycache.ClientQueryCacheContext
 
ClientQueryCacheEndToEndConstructor - Class in com.hazelcast.client.impl.querycache.subscriber
Client-side implementation of QueryCacheEndToEndConstructor.
ClientQueryCacheEndToEndConstructor(QueryCacheRequest) - Constructor for class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheEndToEndConstructor
 
ClientQueryCacheEventService - Class in com.hazelcast.client.impl.querycache.subscriber
Client side event service implementation for query cache.
ClientQueryCacheEventService(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheEventService
 
ClientQueryCacheScheduler - Class in com.hazelcast.client.impl.querycache.subscriber
Client side implementation of QueryCacheScheduler.
ClientQueryCacheScheduler(ClientExecutionService) - Constructor for class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheScheduler
 
ClientQueueProxy<E> - Class in com.hazelcast.client.impl.proxy
Proxy implementation of IQueue.
ClientQueueProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
ClientRaftProxyFactory - Class in com.hazelcast.client.cp.internal.datastructures.proxy
Creates client-side proxies of the CP data structures
ClientRaftProxyFactory(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.cp.internal.datastructures.proxy.ClientRaftProxyFactory
 
ClientRegistrationKey - Class in com.hazelcast.client.impl.spi.impl.listener
 
ClientRegistrationKey(UUID, EventHandler, ListenerMessageCodec) - Constructor for class com.hazelcast.client.impl.spi.impl.listener.ClientRegistrationKey
 
ClientRegistrationKey(UUID) - Constructor for class com.hazelcast.client.impl.spi.impl.listener.ClientRegistrationKey
 
ClientReliableMessageRunner<E> - Class in com.hazelcast.client.impl.proxy
Client implementation of MessageRunner
ClientReliableTopicConfig - Class in com.hazelcast.client.config
Contains the ReliableTopic configuration for a client.
ClientReliableTopicConfig() - Constructor for class com.hazelcast.client.config.ClientReliableTopicConfig
 
ClientReliableTopicConfig(String) - Constructor for class com.hazelcast.client.config.ClientReliableTopicConfig
Creates a new ReliableTopicConfig with default settings.
ClientReliableTopicConfig(ClientReliableTopicConfig) - Constructor for class com.hazelcast.client.config.ClientReliableTopicConfig
Create a clone of given reliable topic
ClientReliableTopicProxy<E> - Class in com.hazelcast.client.impl.proxy
Reliable proxy implementation of ITopic.
ClientReliableTopicProxy(String, ClientContext, HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.impl.proxy.ClientReliableTopicProxy
 
ClientRemoveAllListenersCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ClientRemoveAllListenersCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientRemoveAllListenersCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientRemoveDistributedObjectListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ClientRemoveDistributedObjectListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientRemoveDistributedObjectListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientRemovePartitionLostListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ClientRemovePartitionLostListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientRemovePartitionLostListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientReplicatedMapProxy<K,V> - Class in com.hazelcast.client.impl.proxy
The replicated map client side proxy implementation proxying all requests to a member node
ClientReplicatedMapProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
ClientResponseHandlerSupplier - Class in com.hazelcast.client.impl.spi.impl
A Supplier for Supplier instance that processes responses for client invocations.
ClientResponseHandlerSupplier(AbstractClientInvocationService, ConcurrencyDetection) - Constructor for class com.hazelcast.client.impl.spi.impl.ClientResponseHandlerSupplier
 
ClientRingbufferProxy<E> - Class in com.hazelcast.client.impl.proxy
Proxy implementation of Ringbuffer.
ClientRingbufferProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.impl.proxy.ClientRingbufferProxy
 
ClientScheduledExecutorProxy - Class in com.hazelcast.client.impl.proxy
Client proxy implementation of IScheduledExecutorService.
ClientScheduledExecutorProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
ClientScheduledFutureProxy<V> - Class in com.hazelcast.client.impl.proxy
Proxy implementation of IScheduledFuture.
ClientSecurityConfig - Class in com.hazelcast.client.config
Contains the security configuration for the client.
ClientSecurityConfig() - Constructor for class com.hazelcast.client.config.ClientSecurityConfig
 
ClientSecurityConfig(ClientSecurityConfig) - Constructor for class com.hazelcast.client.config.ClientSecurityConfig
 
ClientSelector - Interface in com.hazelcast.client.impl
 
ClientSelectors - Class in com.hazelcast.client.impl
 
ClientService - Interface in com.hazelcast.client
ClientService allows you to query connected Clients and attach/detach ClientListeners to listen to connection events.
ClientServiceNotFoundException - Exception in com.hazelcast.client.impl.spi.impl
A IllegalArgumentException that indicates that a requested client service doesn't exist.
ClientServiceNotFoundException(String) - Constructor for exception com.hazelcast.client.impl.spi.impl.ClientServiceNotFoundException
 
ClientServiceProxy - Class in com.hazelcast.client.impl
The default implementation of the ClientService.
ClientServiceProxy(Node) - Constructor for class com.hazelcast.client.impl.ClientServiceProxy
 
ClientSetProxy<E> - Class in com.hazelcast.client.impl.proxy
Proxy implementation of ISet.
ClientSetProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.impl.proxy.ClientSetProxy
 
ClientStateListener - Class in com.hazelcast.client.util
Helper class for the user to track the lifecycle state of the client.
ClientStateListener(ClientConfig) - Constructor for class com.hazelcast.client.util.ClientStateListener
Registers this instance with the provided client configuration
ClientStatisticsCodec - Class in com.hazelcast.client.impl.protocol.codec
The statistics is a String that is composed of key=value pairs separated by ',' .
ClientStatisticsCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientStatisticsCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ClientStatisticsMessageTask - Class in com.hazelcast.client.impl.protocol.task
 
ClientStatisticsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ClientStatisticsMessageTask
 
ClientSubscriberContext - Class in com.hazelcast.client.impl.querycache.subscriber
SubscriberContext implementation for client side.
ClientSubscriberContext(QueryCacheContext) - Constructor for class com.hazelcast.client.impl.querycache.subscriber.ClientSubscriberContext
 
ClientSubscriberContextSupport - Class in com.hazelcast.client.impl.querycache.subscriber
SubscriberContextSupport implementation for client side.
ClientSubscriberContextSupport() - Constructor for class com.hazelcast.client.impl.querycache.subscriber.ClientSubscriberContextSupport
 
ClientTopicProxy<E> - Class in com.hazelcast.client.impl.proxy
Proxy implementation of ITopic.
ClientTopicProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.impl.proxy.ClientTopicProxy
 
ClientTransactionContext - Interface in com.hazelcast.client.impl.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.impl.spi
Manages the execution of client transactions and provides TransactionContexts.
ClientTransactionManagerServiceImpl - Class in com.hazelcast.client.impl.spi.impl
 
ClientTransactionManagerServiceImpl(HazelcastClientInstanceImpl, LoadBalancer) - Constructor for class com.hazelcast.client.impl.spi.impl.ClientTransactionManagerServiceImpl
 
ClientTransactionUtil - Class in com.hazelcast.client.impl.proxy.txn
Contains static method that is used from client transaction classes.
ClientTxnListProxy<E> - Class in com.hazelcast.client.impl.proxy.txn
Proxy implementation of TransactionalList.
ClientTxnListProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.impl.proxy.txn.ClientTxnListProxy
 
ClientTxnMapProxy<K,V> - Class in com.hazelcast.client.impl.proxy.txn
Proxy implementation of TransactionalMap interface.
ClientTxnMapProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
ClientTxnMultiMapProxy<K,V> - Class in com.hazelcast.client.impl.proxy.txn
Proxy implementation of TransactionalMultiMap
ClientTxnMultiMapProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.impl.proxy.txn.ClientTxnMultiMapProxy
 
ClientTxnQueueProxy<E> - Class in com.hazelcast.client.impl.proxy.txn
Proxy implementation of TransactionalQueue.
ClientTxnQueueProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.impl.proxy.txn.ClientTxnQueueProxy
 
ClientTxnSetProxy<E> - Class in com.hazelcast.client.impl.proxy.txn
Proxy implementation of TransactionalSet.
ClientTxnSetProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.impl.proxy.txn.ClientTxnSetProxy
 
ClientType - Enum in com.hazelcast.client
Type of a Hazelcast client.
clientType - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec.RequestParameters
The type of the client.
clientType - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec.RequestParameters
The type of the client.
clientType - Variable in class com.hazelcast.internal.management.dto.ClientEndPointDTO
 
ClientTypes - Class in com.hazelcast.client.impl
Constants class that contains the different types of clients.
ClientUserCodeDeploymentConfig - Class in com.hazelcast.client.config
Configuration of User Code Deployment.
ClientUserCodeDeploymentConfig() - Constructor for class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
ClientUserCodeDeploymentConfig(ClientUserCodeDeploymentConfig) - Constructor for class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
ClientUserCodeDeploymentService - Class in com.hazelcast.client.impl.spi.impl
 
ClientUserCodeDeploymentService(ClientUserCodeDeploymentConfig, ClassLoader) - Constructor for class com.hazelcast.client.impl.spi.impl.ClientUserCodeDeploymentService
 
clientUuid - Variable in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
 
ClientViewUnifiedEndpointManager - Class in com.hazelcast.internal.nio.tcp
 
Clock - Class in com.hazelcast.internal.util
Abstracts the system clock to simulate different clocks without changing the actual system time.
Clock.ClockImpl - Class in com.hazelcast.internal.util
Extend this class if you want to provide your own clock implementation.
ClockImpl() - Constructor for class com.hazelcast.internal.util.Clock.ClockImpl
 
ClockProperties - Class in com.hazelcast.internal.util
Utility class to set system parameters for the clock implementation.
clone() - Method in class com.hazelcast.internal.management.TimedMemberState
 
clone() - Method in class com.hazelcast.internal.util.collection.InflatableSet
Returns a shallow copy of this InflatableSet instance: the keys and values themselves are not cloned.
cloneForSnapshot() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchRegistry
 
cloneForSnapshot() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreRegistry
 
cloneForSnapshot(BlockingResource<W>) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.BlockingResource
 
cloneForSnapshot() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
cloneNode(boolean) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
cloneWithoutValue() - Method in class com.hazelcast.map.impl.querycache.event.LocalEntryEventData
 
close() - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
close(ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
close(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
close(boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
close() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
close() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
 
close(ClassLoader) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
 
close(URI, ClassLoader) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
 
close(boolean) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Close is equivalent to below operations in the given order: close resources. unregister all listeners.
close() - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
close(String, Throwable) - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
close() - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
close() - Method in class com.hazelcast.cp.internal.raft.impl.persistence.NopRaftStateStore
 
close() - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
close() - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
close() - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
close() - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
close() - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
close() - Method in class com.hazelcast.internal.networking.AbstractChannel
 
close() - Method in interface com.hazelcast.internal.networking.Channel
Closes the Channel.
close(String, Throwable) - Method in interface com.hazelcast.internal.nio.Connection
Closes this connection.
close(Connection, String) - Static method in class com.hazelcast.internal.nio.IOUtil
 
close(ServerSocket) - Static method in class com.hazelcast.internal.nio.IOUtil
Quietly attempts to close a ServerSocket, swallowing any exception.
close(Socket) - Static method in class com.hazelcast.internal.nio.IOUtil
Quietly attempts to close a Socket, swallowing any exception.
close(String, Throwable) - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
close() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
close() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
close() - Method in class com.hazelcast.internal.usercodedeployment.impl.GlobalMutex
 
close() - Method in class com.hazelcast.internal.util.BufferingInputStream
 
close() - Method in class com.hazelcast.internal.util.ContextMutexFactory.Mutex
 
close(EventRegistration) - Method in interface com.hazelcast.spi.impl.eventservice.EventService
Closes an EventRegistration.
close(EventRegistration) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
close0() - Method in class com.hazelcast.internal.networking.AbstractChannel
Template method that is called when the Channel is closed.
close0() - Method in class com.hazelcast.internal.networking.nio.NioChannel
 
CLOSE_INACTIVE_SESSIONS_OP - Static variable in class com.hazelcast.cp.internal.session.RaftSessionServiceDataSerializerHook
 
CLOSE_SESSION_OP - Static variable in class com.hazelcast.cp.internal.session.RaftSessionServiceDataSerializerHook
 
closeableListeners - Variable in class com.hazelcast.cache.impl.AbstractCacheService
 
closeConnection() - Method in class com.hazelcast.internal.nio.ascii.TextDecoder
 
closeInactiveSessions(CPGroupId, Collection<Long>) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
CloseInactiveSessionsOp - Class in com.hazelcast.cp.internal.session.operation
Closes inactive sessions.
CloseInactiveSessionsOp() - Constructor for class com.hazelcast.cp.internal.session.operation.CloseInactiveSessionsOp
 
CloseInactiveSessionsOp(Collection<Long>) - Constructor for class com.hazelcast.cp.internal.session.operation.CloseInactiveSessionsOp
 
closeListeners() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
closeResource(Closeable) - Static method in class com.hazelcast.internal.nio.IOUtil
Quietly attempts to close a Closeable resource, swallowing any exception.
closeSegments(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
closeSession(RaftGroupId, Long) - Method in class com.hazelcast.client.cp.internal.session.ClientProxySessionManager
 
closeSession(RaftGroupId, Long) - Method in class com.hazelcast.cp.internal.session.AbstractProxySessionManager
Closes the given session on the Raft group
closeSession(RaftGroupId, Long) - Method in class com.hazelcast.cp.internal.session.ProxySessionManagerService
 
closeSession(CPGroupId, long) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
CloseSessionMessageTask - Class in com.hazelcast.cp.internal.session.client
Client message task for CloseSessionOp
CloseSessionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.session.client.CloseSessionMessageTask
 
CloseSessionOp - Class in com.hazelcast.cp.internal.session.operation
Closes the given session on the Raft group and notifies services via the SessionAwareService interface.
CloseSessionOp() - Constructor for class com.hazelcast.cp.internal.session.operation.CloseSessionOp
 
CloseSessionOp(long) - Constructor for class com.hazelcast.cp.internal.session.operation.CloseSessionOp
 
CLOUD_URL_BASE_PROPERTY - Static variable in class com.hazelcast.client.impl.spi.impl.discovery.HazelcastCloudDiscovery
Internal client property to change base url of cloud discovery endpoint.
Cluster - Interface in com.hazelcast.cluster
Hazelcast cluster interface.
CLUSTER - Static variable in class com.hazelcast.internal.nio.Protocols
Protocol that is used among nodes
CLUSTER_MISMATCH - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
CLUSTER_SHUTDOWN_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
CLUSTER_STATE_CHANGE - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
CLUSTER_STATE_TRANSACTION_LOG_RECORD - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
ClusterClock - Interface in com.hazelcast.internal.cluster
 
ClusterClockImpl - Class in com.hazelcast.internal.cluster.impl
 
ClusterClockImpl(ILogger) - Constructor for class com.hazelcast.internal.cluster.impl.ClusterClockImpl
 
ClusterConnectorService - Interface in com.hazelcast.client.impl.connection.nio
selects a connection to listen cluster state(membership and partition listener), Keeps those listeners available when connection disconnected by picking a new connection.
ClusterConnectorServiceImpl - Class in com.hazelcast.client.impl.connection.nio
selects a connection to listen cluster state(membership and partition listener), Keeps those listeners available when connection disconnected by picking a new connection.
ClusterConnectorServiceImpl(HazelcastClientInstanceImpl, ClientConnectionManagerImpl, ClientConnectionStrategy, ClientDiscoveryService) - Constructor for class com.hazelcast.client.impl.connection.nio.ClusterConnectorServiceImpl
 
ClusterDataSerializerHook - Class in com.hazelcast.internal.cluster.impl
 
ClusterDataSerializerHook() - Constructor for class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
ClusterFailureDetector - Interface in com.hazelcast.internal.cluster.fd
Cluster failure detector tracks heartbeats of the members and decides liveness/availability of them.
ClusterFailureDetectorType - Enum in com.hazelcast.internal.cluster.fd
 
ClusterHeartbeatManager - Class in com.hazelcast.internal.cluster.impl
ClusterHeartbeatManager manages the heartbeat sending and receiving process of a node.
ClusterHotRestartStatusDTO - Class in com.hazelcast.internal.management.dto
A DTO for Hot Restart status of cluster and all members.
ClusterHotRestartStatusDTO() - Constructor for class com.hazelcast.internal.management.dto.ClusterHotRestartStatusDTO
 
ClusterHotRestartStatusDTO(HotRestartClusterDataRecoveryPolicy, ClusterHotRestartStatusDTO.ClusterHotRestartStatus, long, long, Map<String, ClusterHotRestartStatusDTO.MemberHotRestartStatus>) - Constructor for class com.hazelcast.internal.management.dto.ClusterHotRestartStatusDTO
 
ClusterHotRestartStatusDTO.ClusterHotRestartStatus - Enum in com.hazelcast.internal.management.dto
 
ClusterHotRestartStatusDTO.MemberHotRestartStatus - Enum in com.hazelcast.internal.management.dto
 
clusterId - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec.RequestParameters
the expected id of the cluster.
clusterId - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec.ResponseParameters
the expected id of the cluster.
clusterId - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec.RequestParameters
the expected id of the cluster.
clusterId - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec.ResponseParameters
the expected id of the cluster.
clusterId - Variable in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
 
clusterJoinManager - Variable in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
ClusterJoinManager - Class in com.hazelcast.internal.cluster.impl
ClusterJoinManager manages member join process.
ClusterMismatchOp - Class in com.hazelcast.internal.cluster.impl.operations
 
ClusterMismatchOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.ClusterMismatchOp
 
ClusterPermission - Class in com.hazelcast.security.permission
 
ClusterPermission(String) - Constructor for class com.hazelcast.security.permission.ClusterPermission
 
ClusterPermissionCollection - Class in com.hazelcast.security.permission
 
ClusterPermissionCollection() - Constructor for class com.hazelcast.security.permission.ClusterPermissionCollection
 
ClusterPermissionCollection(Class<? extends Permission>) - Constructor for class com.hazelcast.security.permission.ClusterPermissionCollection
 
ClusterPropsRequest - Class in com.hazelcast.internal.management.request
Request for cluster properties.
ClusterPropsRequest() - Constructor for class com.hazelcast.internal.management.request.ClusterPropsRequest
 
clusterService - Variable in class com.hazelcast.instance.impl.Node
 
ClusterService - Interface in com.hazelcast.internal.cluster
A service responsible for member related functionality, e.g.
clusterService - Variable in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
clusterService - Variable in class com.hazelcast.map.impl.query.PartitionScanRunner
 
clusterService - Variable in class com.hazelcast.map.impl.query.QueryRunner
 
ClusterServiceImpl - Class in com.hazelcast.internal.cluster.impl
 
ClusterServiceImpl(Node, MemberImpl) - Constructor for class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
ClusterState - Enum in com.hazelcast.cluster
ClusterState are several possible states of the cluster where each state can allow and/or deny specific actions and/or change behavior of specific actions.
ClusterStateChange<T> - Class in com.hazelcast.internal.cluster.impl
Wrapper object indicating a change in the cluster state - it may be cluster state change or cluster version change.
ClusterStateChange() - Constructor for class com.hazelcast.internal.cluster.impl.ClusterStateChange
 
ClusterStateChange(T) - Constructor for class com.hazelcast.internal.cluster.impl.ClusterStateChange
 
ClusterStateListener - Interface in com.hazelcast.internal.cluster
Used by services which needs to act against new cluster state.
ClusterStateManager - Class in com.hazelcast.internal.cluster.impl
ClusterStateManager stores cluster state and manages cluster state transactions.
ClusterStateTransactionLogRecord - Class in com.hazelcast.internal.cluster.impl
TransactionLogRecord implementation to be used in ClusterState transactions.
ClusterStateTransactionLogRecord() - Constructor for class com.hazelcast.internal.cluster.impl.ClusterStateTransactionLogRecord
 
ClusterStateTransactionLogRecord(ClusterStateChange, Address, Address, UUID, long, int, int, boolean) - Constructor for class com.hazelcast.internal.cluster.impl.ClusterStateTransactionLogRecord
 
ClusterTopologyChangedException - Exception in com.hazelcast.internal.cluster.impl
Thrown when a cluster topology change is detected.
ClusterTopologyChangedException() - Constructor for exception com.hazelcast.internal.cluster.impl.ClusterTopologyChangedException
 
ClusterTopologyChangedException(String) - Constructor for exception com.hazelcast.internal.cluster.impl.ClusterTopologyChangedException
 
ClusterVersionListener - Interface in com.hazelcast.internal.cluster
Listeners interested in acting upon cluster version update should implement this interface.
clusterVersionListeners - Variable in class com.hazelcast.instance.impl.DefaultNodeExtension
 
ClusterWideConfigurationService - Class in com.hazelcast.internal.dynamicconfig
 
ClusterWideConfigurationService(NodeEngine, DynamicConfigListener) - Constructor for class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
ClusterWideConfigurationService.Merger - Class in com.hazelcast.internal.dynamicconfig
 
ClusterWideIterator<K,V> - Class in com.hazelcast.cache.impl
Cluster-wide iterator for ICache.
ClusterWideIterator(CacheProxy<K, V>, boolean) - Constructor for class com.hazelcast.cache.impl.ClusterWideIterator
 
ClusterWideIterator(CacheProxy<K, V>, int, boolean) - Constructor for class com.hazelcast.cache.impl.ClusterWideIterator
 
ClusterWideIterator(CacheProxy<K, V>, int, int, boolean) - Constructor for class com.hazelcast.cache.impl.ClusterWideIterator
 
clusterWideUpdateManagementCenterUrl(String) - Method in class com.hazelcast.internal.management.ManagementCenterService
 
coalesce - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateCodec.RequestParameters
Flag to enable/disable coalescing.
coalesce - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateWithValueCodec.RequestParameters
Flag to enable/disable coalescing.
CoalescingDelayedTrigger - Class in com.hazelcast.internal.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.internal.util.scheduler.CoalescingDelayedTrigger
 
CodecUtil - Class in com.hazelcast.client.impl.protocol.codec.builtin
 
collect(MetricsCollector) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
 
collect(MetricsCollector) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
Collects the content of the MetricsRegistry.
COLLECT_REMOTE_TX - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
COLLECT_REMOTE_TX_FACTORY - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
collectAllServiceNamespaces(PartitionReplicationEvent, Set<ServiceNamespace>) - Method in class com.hazelcast.wan.impl.DelegatingWanReplicationScheme
Collect the namespaces of all queues that should be replicated by the replication event.
collectAllServiceNamespaces(PartitionReplicationEvent, Set<ServiceNamespace>) - Method in interface com.hazelcast.wan.WanReplicationPublisher
Collect the namespaces of all WAN event containers that should be replicated by the replication event.
collectDouble(String, double, Set<MetricTarget>) - Method in interface com.hazelcast.internal.metrics.collectors.MetricsCollector
 
collectException(String, Exception, Set<MetricTarget>) - Method in interface com.hazelcast.internal.metrics.collectors.MetricsCollector
 
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_ALL - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
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_CLEAR - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
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_CONTAINS - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
COLLECTION_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
COLLECTION_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
COLLECTION_EVENT - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
COLLECTION_EVENT_FILTER - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
COLLECTION_GET_ALL - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
COLLECTION_IS_EMPTY - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
COLLECTION_ITEM - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
COLLECTION_MERGE - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
COLLECTION_MERGE_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
COLLECTION_MERGING_VALUE - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
COLLECTION_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
COLLECTION_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
COLLECTION_PREPARE - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
COLLECTION_PREPARE_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
COLLECTION_REMOVE - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
COLLECTION_REMOVE_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
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_TRANSACTION_LOG_RECORD - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
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
 
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
 
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
 
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
 
CollectionCommitBackupOperation - Class in com.hazelcast.collection.impl.txncollection.operations
a wrapper for running all commit backup operations at once
CollectionCommitBackupOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitBackupOperation
 
CollectionCommitBackupOperation(String, String, List<Operation>) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitBackupOperation
 
CollectionCommitOperation - Class in com.hazelcast.collection.impl.txncollection.operations
a wrapper for running all commit operations at once
CollectionCommitOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitOperation
 
CollectionCommitOperation(int, String, String, List<Operation>) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitOperation
 
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
 
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
 
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
 
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
 
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
 
CollectionMergeBackupOperation - Class in com.hazelcast.collection.impl.collection.operations
Creates backups for merged collection items after split-brain healing with a SplitBrainMergePolicy.
CollectionMergeBackupOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionMergeBackupOperation
 
CollectionMergeBackupOperation(String, Collection<CollectionItem>) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionMergeBackupOperation
 
CollectionMergeOperation - Class in com.hazelcast.collection.impl.collection.operations
Merges a SplitBrainMergeTypes.CollectionMergeTypes for split-brain healing with a SplitBrainMergePolicy.
CollectionMergeOperation(String, SplitBrainMergePolicy<Collection<Object>, SplitBrainMergeTypes.CollectionMergeTypes>, SplitBrainMergeTypes.CollectionMergeTypes) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionMergeOperation
 
CollectionMergeOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionMergeOperation
 
CollectionMergingValueImpl - Class in com.hazelcast.spi.impl.merge
CollectionMergingValueImpl() - Constructor for class com.hazelcast.spi.impl.merge.CollectionMergingValueImpl
 
CollectionMergingValueImpl(SerializationService) - Constructor for class com.hazelcast.spi.impl.merge.CollectionMergingValueImpl
 
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
 
CollectionPrepareBackupOperation - Class in com.hazelcast.collection.impl.txncollection.operations
 
CollectionPrepareBackupOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareBackupOperation
 
CollectionPrepareBackupOperation(String, long[], UUID) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareBackupOperation
 
CollectionPrepareOperation - Class in com.hazelcast.collection.impl.txncollection.operations
 
CollectionPrepareOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareOperation
 
CollectionPrepareOperation(int, String, String, long[], UUID) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareOperation
 
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
 
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
 
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
 
CollectionReserveAddOperation - Class in com.hazelcast.collection.impl.txncollection.operations
 
CollectionReserveAddOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveAddOperation
 
CollectionReserveAddOperation(String, UUID, 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, UUID) - 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[]) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackBackupOperation
 
CollectionRollbackOperation - Class in com.hazelcast.collection.impl.txncollection.operations
 
CollectionRollbackOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackOperation
 
CollectionRollbackOperation(int, String, String, long[]) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackOperation
 
collections() - Method in class com.hazelcast.internal.metrics.managementcenter.MetricsResultSet
 
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
 
CollectionTransactionLogRecord - Class in com.hazelcast.collection.impl.txncollection
This class contains Transaction log for the Collection.
CollectionTransactionLogRecord() - Constructor for class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
 
CollectionTransactionLogRecord(String, UUID, String, int) - Constructor for class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
 
CollectionTransactionRollbackOperation - Class in com.hazelcast.collection.impl.txncollection.operations
 
CollectionTransactionRollbackOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTransactionRollbackOperation
 
CollectionTransactionRollbackOperation(String, UUID) - 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
 
CollectionTxnOperation - Interface in com.hazelcast.collection.impl.txncollection
 
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
 
CollectionTxnUtil - Class in com.hazelcast.collection.impl
 
collectionType - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMultiMapConfigCodec.RequestParameters
value collection type.
CollectionUtil - Class in com.hazelcast.internal.util
Various collection utility methods.
collectLong(String, long, Set<MetricTarget>) - Method in interface com.hazelcast.internal.metrics.collectors.MetricsCollector
 
collectNoValue(String, Set<MetricTarget>) - Method in interface com.hazelcast.internal.metrics.collectors.MetricsCollector
 
collector - Variable in class com.hazelcast.spi.impl.merge.AbstractContainerMerger
 
CollectRemoteTransactionsOperation - Class in com.hazelcast.transaction.impl.xa.operations
 
CollectRemoteTransactionsOperation() - Constructor for class com.hazelcast.transaction.impl.xa.operations.CollectRemoteTransactionsOperation
 
CollectRemoteTransactionsOperationSupplier - Class in com.hazelcast.client.impl
 
CollectRemoteTransactionsOperationSupplier() - Constructor for class com.hazelcast.client.impl.CollectRemoteTransactionsOperationSupplier
 
column - Variable in class com.hazelcast.internal.json.Location
The column number, starting at 1.
com.hazelcast - package com.hazelcast
This package contains PlaceHolder
com.hazelcast.aggregation - package com.hazelcast.aggregation
Contains classes related to aggregations.
com.hazelcast.aggregation.impl - package com.hazelcast.aggregation.impl
 
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.event - package com.hazelcast.cache.impl.event
Event classes to define listenters for JCache other than EntryListener
com.hazelcast.cache.impl.eviction - package com.hazelcast.cache.impl.eviction
 
com.hazelcast.cache.impl.journal - package com.hazelcast.cache.impl.journal
 
com.hazelcast.cache.impl.maxsize - package com.hazelcast.cache.impl.maxsize
Max-Size policy interfaces for cache.
com.hazelcast.cache.impl.maxsize.impl - package com.hazelcast.cache.impl.maxsize.impl
Max-Size policy implementations for cache.
com.hazelcast.cache.impl.merge - package com.hazelcast.cache.impl.merge
This package contains merge functionality for Hazelcast cache.
com.hazelcast.cache.impl.merge.entry - package com.hazelcast.cache.impl.merge.entry
This package contains merge entry internal interfaces and functionality for Hazelcast cache.
com.hazelcast.cache.impl.operation - package com.hazelcast.cache.impl.operation
Hazelcast JSR-107 aka JCache implementation
com.hazelcast.cache.impl.record - package com.hazelcast.cache.impl.record
Hazelcast JSR-107 aka JCache implementation Internal record store
com.hazelcast.cache.impl.tenantcontrol - package com.hazelcast.cache.impl.tenantcontrol
 
com.hazelcast.cache.journal - package com.hazelcast.cache.journal
Contains EventJournal event interface for ICache.
com.hazelcast.cardinality - package com.hazelcast.cardinality
This package contains Cardinality Estimator functionality for Hazelcast.
com.hazelcast.cardinality.impl - package com.hazelcast.cardinality.impl
 
com.hazelcast.cardinality.impl.hyperloglog - package com.hazelcast.cardinality.impl.hyperloglog
This package contains spec for the HyperLogLog data-structure.
com.hazelcast.cardinality.impl.hyperloglog.impl - package com.hazelcast.cardinality.impl.hyperloglog.impl
This package contains implementations of HyperLogLog.
com.hazelcast.cardinality.impl.operations - package com.hazelcast.cardinality.impl.operations
This package contains the operations on the CardinalityEstimator.
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.cache.impl.nearcache.invalidation - package com.hazelcast.client.cache.impl.nearcache.invalidation
 
com.hazelcast.client.config - package com.hazelcast.client.config
Contains classes related to config for com.hazelcast.client
com.hazelcast.client.console - package com.hazelcast.client.console
This package contains ClientConsoleApp
com.hazelcast.client.cp.internal - package com.hazelcast.client.cp.internal
Contains client-side impl classes of the CP subsystem
com.hazelcast.client.cp.internal.datastructures.atomiclong - package com.hazelcast.client.cp.internal.datastructures.atomiclong
Contains client-side proxy impl of Raft-based IAtomicLong
com.hazelcast.client.cp.internal.datastructures.atomicref - package com.hazelcast.client.cp.internal.datastructures.atomicref
Contains client-side proxy impl of Raft-based IAtomicReference
com.hazelcast.client.cp.internal.datastructures.countdownlatch - package com.hazelcast.client.cp.internal.datastructures.countdownlatch
Contains client-side proxy impl of Raft-based ICountDownLatch
com.hazelcast.client.cp.internal.datastructures.lock - package com.hazelcast.client.cp.internal.datastructures.lock
Contains client-side proxy impl of Raft-based FencedLock
com.hazelcast.client.cp.internal.datastructures.proxy - package com.hazelcast.client.cp.internal.datastructures.proxy
Contains APIs to create client-side proxies of the CP data structures
com.hazelcast.client.cp.internal.datastructures.semaphore - package com.hazelcast.client.cp.internal.datastructures.semaphore
Contains client-side proxy impl of Raft-based ISemaphore
com.hazelcast.client.cp.internal.session - package com.hazelcast.client.cp.internal.session
Contains client-side impl of the Raft proxy session manager
com.hazelcast.client.impl - package com.hazelcast.client.impl
Implementation classes of the com.hazelcast.client interfaces
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.clientside - package com.hazelcast.client.impl.clientside
Contains most of the client side HazelcastInstance implementation functionality.
com.hazelcast.client.impl.connection - package com.hazelcast.client.impl.connection
Provides connection interfaces/classes for com.hazelcast.client Everything in this package and its subpackages is private.
com.hazelcast.client.impl.connection.nio - package com.hazelcast.client.impl.connection.nio
Contains classes related to New IO for com.hazelcast.client.connection
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
 
com.hazelcast.client.impl.protocol.codec.builtin - package com.hazelcast.client.impl.protocol.codec.builtin
 
com.hazelcast.client.impl.protocol.codec.custom - package com.hazelcast.client.impl.protocol.codec.custom
 
com.hazelcast.client.impl.protocol.codec.holder - package com.hazelcast.client.impl.protocol.codec.holder
 
com.hazelcast.client.impl.protocol.exception - package com.hazelcast.client.impl.protocol.exception
 
com.hazelcast.client.impl.protocol.task - package com.hazelcast.client.impl.protocol.task
Client tasks associated with requests.
com.hazelcast.client.impl.protocol.task.cache - package com.hazelcast.client.impl.protocol.task.cache
Client protocol tasks implementations for JCache
com.hazelcast.client.impl.protocol.task.cardinality - package com.hazelcast.client.impl.protocol.task.cardinality
 
com.hazelcast.client.impl.protocol.task.crdt.pncounter - package com.hazelcast.client.impl.protocol.task.crdt.pncounter
 
com.hazelcast.client.impl.protocol.task.dynamicconfig - package com.hazelcast.client.impl.protocol.task.dynamicconfig
 
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.executorservice.durable - package com.hazelcast.client.impl.protocol.task.executorservice.durable
 
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.map - package com.hazelcast.client.impl.protocol.task.map
Client protocol tasks implementations for map
com.hazelcast.client.impl.protocol.task.metrics - package com.hazelcast.client.impl.protocol.task.metrics
 
com.hazelcast.client.impl.protocol.task.multimap - package com.hazelcast.client.impl.protocol.task.multimap
Client protocol tasks implementations for multi map
com.hazelcast.client.impl.protocol.task.queue - package com.hazelcast.client.impl.protocol.task.queue
Client protocol tasks implementations for Queue
com.hazelcast.client.impl.protocol.task.replicatedmap - package com.hazelcast.client.impl.protocol.task.replicatedmap
Client protocol tasks implementations for ReplicatedMap
com.hazelcast.client.impl.protocol.task.ringbuffer - package com.hazelcast.client.impl.protocol.task.ringbuffer
Client protocol tasks implementations for Ringbuffer
com.hazelcast.client.impl.protocol.task.scheduledexecutor - package com.hazelcast.client.impl.protocol.task.scheduledexecutor
 
com.hazelcast.client.impl.protocol.task.set - package com.hazelcast.client.impl.protocol.task.set
Client protocol tasks implementations for set
com.hazelcast.client.impl.protocol.task.topic - package com.hazelcast.client.impl.protocol.task.topic
Client protocol tasks implementations for Topic
com.hazelcast.client.impl.protocol.task.transaction - package com.hazelcast.client.impl.protocol.task.transaction
Client protocol tasks implementations for Transaction related
com.hazelcast.client.impl.protocol.task.transactionallist - package com.hazelcast.client.impl.protocol.task.transactionallist
Client protocol tasks implementations for Transactional List
com.hazelcast.client.impl.protocol.task.transactionalmap - package com.hazelcast.client.impl.protocol.task.transactionalmap
Client protocol tasks implementations for Transactional Map
com.hazelcast.client.impl.protocol.task.transactionalmultimap - package com.hazelcast.client.impl.protocol.task.transactionalmultimap
Client protocol tasks implementations for Transactional MultiMap
com.hazelcast.client.impl.protocol.task.transactionalqueue - package com.hazelcast.client.impl.protocol.task.transactionalqueue
Client protocol tasks implementations for Transactional Queue
com.hazelcast.client.impl.protocol.task.transactionalset - package com.hazelcast.client.impl.protocol.task.transactionalset
Client protocol tasks implementations for Transactional Set
com.hazelcast.client.impl.protocol.util - package com.hazelcast.client.impl.protocol.util
Protocol utils
com.hazelcast.client.impl.proxy - package com.hazelcast.client.impl.proxy
This package contains client side proxy implementations of the different Hazelcast data structures and operation types
com.hazelcast.client.impl.proxy.txn - package com.hazelcast.client.impl.proxy.txn
Contains classes related to proxy for client transactions
com.hazelcast.client.impl.proxy.txn.xa - package com.hazelcast.client.impl.proxy.txn.xa
Contains classes related to proxy for XA
com.hazelcast.client.impl.querycache - package com.hazelcast.client.impl.querycache
Contains query cache internal implementations for client side.
com.hazelcast.client.impl.querycache.subscriber - package com.hazelcast.client.impl.querycache.subscriber
Contains Hazelcast Enterprise version client-side query cache subscriber implementation classes.
com.hazelcast.client.impl.spi - package com.hazelcast.client.impl.spi
Contains classes/interfaces related to the Hazelcast client Service Provider Interface.
com.hazelcast.client.impl.spi.impl - package com.hazelcast.client.impl.spi.impl
Provides util classes for the Hazelcast client SPI.
com.hazelcast.client.impl.spi.impl.discovery - package com.hazelcast.client.impl.spi.impl.discovery
 
com.hazelcast.client.impl.spi.impl.listener - package com.hazelcast.client.impl.spi.impl.listener
 
com.hazelcast.client.impl.statistics - package com.hazelcast.client.impl.statistics
 
com.hazelcast.client.map.impl - package com.hazelcast.client.map.impl
 
com.hazelcast.client.map.impl.nearcache.invalidation - package com.hazelcast.client.map.impl.nearcache.invalidation
 
com.hazelcast.client.properties - package com.hazelcast.client.properties
Contains the Hazelcast client properties implementation.
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.impl - package com.hazelcast.cluster.impl
 
com.hazelcast.cluster.memberselector - package com.hazelcast.cluster.memberselector
This package contains several MemberSelector implementations.
com.hazelcast.cluster.memberselector.impl - package com.hazelcast.cluster.memberselector.impl
 
com.hazelcast.collection - package com.hazelcast.collection
This package contains classes to support the collection API.
com.hazelcast.collection.impl - package com.hazelcast.collection.impl
 
com.hazelcast.collection.impl.collection - package com.hazelcast.collection.impl.collection
 
com.hazelcast.collection.impl.collection.operations - package com.hazelcast.collection.impl.collection.operations
 
com.hazelcast.collection.impl.common - package com.hazelcast.collection.impl.common
 
com.hazelcast.collection.impl.list - package com.hazelcast.collection.impl.list
This package contains IList functionality for Hazelcast.
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.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.operations - package com.hazelcast.collection.impl.txncollection.operations
 
com.hazelcast.collection.impl.txnlist - package com.hazelcast.collection.impl.txnlist
 
com.hazelcast.collection.impl.txnqueue - package com.hazelcast.collection.impl.txnqueue
 
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.config - package com.hazelcast.config
Provides classes for configuring HazelcastInstance.
com.hazelcast.config.cp - package com.hazelcast.config.cp
This package contains configuration classes for the CPSubsystem
com.hazelcast.config.matcher - package com.hazelcast.config.matcher
Provides implementations for ConfigPatternMatcher.
com.hazelcast.config.properties - package com.hazelcast.config.properties
This package contains the public API for properties defined in the XML configuration.
com.hazelcast.config.replacer - package com.hazelcast.config.replacer
This package contains the public API and default implementation of variable replacers for configuration files.
com.hazelcast.config.replacer.spi - package com.hazelcast.config.replacer.spi
This package contains the SPI for configuration files variable replacers.
com.hazelcast.config.security - package com.hazelcast.config.security
Provides classes for configuring security realms in Hazelcast.
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.cp - package com.hazelcast.cp
Contains public APIs of CP Subsystem
com.hazelcast.cp.exception - package com.hazelcast.cp.exception
Contains exceptions that can be thrown by APIs of CP Subsystem
com.hazelcast.cp.internal - package com.hazelcast.cp.internal
Contains implementation of CP Subsystem
com.hazelcast.cp.internal.client - package com.hazelcast.cp.internal.client
Client support classes for CP subsystem
com.hazelcast.cp.internal.datastructures - package com.hazelcast.cp.internal.datastructures
Contains Raft-based implementations of Hazelcast's concurrency APIs
com.hazelcast.cp.internal.datastructures.atomiclong - package com.hazelcast.cp.internal.datastructures.atomiclong
Contains service classes for the Raft-based IAtomicLong implementation
com.hazelcast.cp.internal.datastructures.atomiclong.client - package com.hazelcast.cp.internal.datastructures.atomiclong.client
Client protocol tasks for the Raft-based AtomicLong implementation
com.hazelcast.cp.internal.datastructures.atomiclong.operation - package com.hazelcast.cp.internal.datastructures.atomiclong.operation
Contains operations for the Raft-based IAtomicLong implementation
com.hazelcast.cp.internal.datastructures.atomiclong.proxy - package com.hazelcast.cp.internal.datastructures.atomiclong.proxy
Contains IAtomicLong functionality based on the Raft algorithm.
com.hazelcast.cp.internal.datastructures.atomicref - package com.hazelcast.cp.internal.datastructures.atomicref
Contains service classes for the Raft-based IAtomicReference implementation
com.hazelcast.cp.internal.datastructures.atomicref.client - package com.hazelcast.cp.internal.datastructures.atomicref.client
Client protocol tasks for the Raft-based AtomicReference implementation
com.hazelcast.cp.internal.datastructures.atomicref.operation - package com.hazelcast.cp.internal.datastructures.atomicref.operation
Contains operations for the Raft-based IAtomicReference implementation
com.hazelcast.cp.internal.datastructures.atomicref.proxy - package com.hazelcast.cp.internal.datastructures.atomicref.proxy
Contains IAtomicReference functionality based on the Raft algorithm.
com.hazelcast.cp.internal.datastructures.countdownlatch - package com.hazelcast.cp.internal.datastructures.countdownlatch
Contains service classes for the Raft-based ICountDownLatch implementation
com.hazelcast.cp.internal.datastructures.countdownlatch.client - package com.hazelcast.cp.internal.datastructures.countdownlatch.client
Client protocol tasks for the Raft-based CountDownLatch implementation
com.hazelcast.cp.internal.datastructures.countdownlatch.operation - package com.hazelcast.cp.internal.datastructures.countdownlatch.operation
Contains operations for the Raft-based ICountDownLatch implementation
com.hazelcast.cp.internal.datastructures.countdownlatch.proxy - package com.hazelcast.cp.internal.datastructures.countdownlatch.proxy
Contains IAtomicLong functionality based on the Raft algorithm.
com.hazelcast.cp.internal.datastructures.exception - package com.hazelcast.cp.internal.datastructures.exception
Contains internal exceptions related to Raft-based data structure implementations
com.hazelcast.cp.internal.datastructures.lock - package com.hazelcast.cp.internal.datastructures.lock
Contains service classes for the Raft-based FencedLock and FencedLock implementation
com.hazelcast.cp.internal.datastructures.lock.client - package com.hazelcast.cp.internal.datastructures.lock.client
Client protocol tasks for the Raft-based Lock implementation
com.hazelcast.cp.internal.datastructures.lock.operation - package com.hazelcast.cp.internal.datastructures.lock.operation
Contains operations for the Raft-based FencedLock implementation
com.hazelcast.cp.internal.datastructures.lock.proxy - package com.hazelcast.cp.internal.datastructures.lock.proxy
Contains FencedLock functionality based on the Raft algorithm.
com.hazelcast.cp.internal.datastructures.semaphore - package com.hazelcast.cp.internal.datastructures.semaphore
Contains service classes for the Raft-based ISemaphore implementation
com.hazelcast.cp.internal.datastructures.semaphore.client - package com.hazelcast.cp.internal.datastructures.semaphore.client
Client protocol tasks for the Raft-based Semaphore implementation
com.hazelcast.cp.internal.datastructures.semaphore.operation - package com.hazelcast.cp.internal.datastructures.semaphore.operation
Contains operations for the Raft-based ISemaphore implementation
com.hazelcast.cp.internal.datastructures.semaphore.proxy - package com.hazelcast.cp.internal.datastructures.semaphore.proxy
Contains ISemaphore functionality based on the Raft algorithm.
com.hazelcast.cp.internal.datastructures.spi - package com.hazelcast.cp.internal.datastructures.spi
Contains the abstractions that is used for managing proxies for the Raft-based data structure implementations
com.hazelcast.cp.internal.datastructures.spi.atomic - package com.hazelcast.cp.internal.datastructures.spi.atomic
 
com.hazelcast.cp.internal.datastructures.spi.blocking - package com.hazelcast.cp.internal.datastructures.spi.blocking
Contains the interfaces and abstractions that are implemented / extended by blocking Raft services, such as Lock, Semaphore, and CountDownLatch
com.hazelcast.cp.internal.datastructures.spi.blocking.operation - package com.hazelcast.cp.internal.datastructures.spi.blocking.operation
Contains the operations that are used by the AbstractBlockingService abstraction
com.hazelcast.cp.internal.datastructures.spi.client - package com.hazelcast.cp.internal.datastructures.spi.client
Contains utilities for creating Raft groups and fetching Raft group ids from clients
com.hazelcast.cp.internal.datastructures.spi.operation - package com.hazelcast.cp.internal.datastructures.spi.operation
Contains the operations that is used for managing proxies for the Raft-based data structure implementations
com.hazelcast.cp.internal.exception - package com.hazelcast.cp.internal.exception
Contains internal exceptions that are being used by CP Subsystem implementation
com.hazelcast.cp.internal.operation - package com.hazelcast.cp.internal.operation
Contains operations for the Raft Invocation SPI
com.hazelcast.cp.internal.operation.integration - package com.hazelcast.cp.internal.operation.integration
Contains Hazelcast operations that carry out Raft RPCs
com.hazelcast.cp.internal.operation.unsafe - package com.hazelcast.cp.internal.operation.unsafe
 
com.hazelcast.cp.internal.persistence - package com.hazelcast.cp.internal.persistence
 
com.hazelcast.cp.internal.raft - package com.hazelcast.cp.internal.raft
Contains abstractions that are defined for the core Raft algorithm implementation
com.hazelcast.cp.internal.raft.command - package com.hazelcast.cp.internal.raft.command
Contains the RaftGroupCmd abstraction and its default impls
com.hazelcast.cp.internal.raft.exception - package com.hazelcast.cp.internal.raft.exception
Contains exception classes that can be thrown by CP Subsystem
com.hazelcast.cp.internal.raft.impl - package com.hazelcast.cp.internal.raft.impl
Contains implementation classes of the Raft algorithm
com.hazelcast.cp.internal.raft.impl.command - package com.hazelcast.cp.internal.raft.impl.command
Contains RaftGroupCmd implementations that are used by the core Raft algorithm implementation
com.hazelcast.cp.internal.raft.impl.dto - package com.hazelcast.cp.internal.raft.impl.dto
Contains structs that are used in Raft RPCs
com.hazelcast.cp.internal.raft.impl.handler - package com.hazelcast.cp.internal.raft.impl.handler
Contains request/response handler tasks.
com.hazelcast.cp.internal.raft.impl.log - package com.hazelcast.cp.internal.raft.impl.log
Contains the log abstraction which is maintained by the Raft algorithm
com.hazelcast.cp.internal.raft.impl.persistence - package com.hazelcast.cp.internal.raft.impl.persistence
 
com.hazelcast.cp.internal.raft.impl.state - package com.hazelcast.cp.internal.raft.impl.state
Contains classes that keep state of Raft nodes
com.hazelcast.cp.internal.raft.impl.task - package com.hazelcast.cp.internal.raft.impl.task
Contains tasks running on leader or leader-candidates.
com.hazelcast.cp.internal.raft.impl.util - package com.hazelcast.cp.internal.raft.impl.util
 
com.hazelcast.cp.internal.raftop - package com.hazelcast.cp.internal.raftop
Contains operations that are used in Hazelcast's Raft implementation
com.hazelcast.cp.internal.raftop.metadata - package com.hazelcast.cp.internal.raftop.metadata
Contains operations that are used in the Metadata CP group
com.hazelcast.cp.internal.raftop.snapshot - package com.hazelcast.cp.internal.raftop.snapshot
Contains operations that are used by Hazelcast to implement Raft's snapshotting mechanism
com.hazelcast.cp.internal.session - package com.hazelcast.cp.internal.session
Contains service classes for the Raft-based ISemaphore implementation
com.hazelcast.cp.internal.session.client - package com.hazelcast.cp.internal.session.client
Client protocol tasks for the Raft-based Session implementation
com.hazelcast.cp.internal.session.operation - package com.hazelcast.cp.internal.session.operation
Contains operations that are internally used by the CP session API
com.hazelcast.cp.internal.util - package com.hazelcast.cp.internal.util
Contains utilities that are used by CP Subsystem implementation
com.hazelcast.cp.lock - package com.hazelcast.cp.lock
Contains locking APIs of CP Subsystem
com.hazelcast.cp.lock.exception - package com.hazelcast.cp.lock.exception
Contains exception classes related to the locking API of CP Subsystem
com.hazelcast.cp.session - package com.hazelcast.cp.session
Contains session abstractions of CP Subsystem
com.hazelcast.crdt - package com.hazelcast.crdt
This package contains the common classes for CRDT (conflict-free replicated data type) implementations based on the Hazelcast infrastructure.
com.hazelcast.crdt.pncounter - package com.hazelcast.crdt.pncounter
This package contains the PN (Positive-Negative) CRDT counter interface.
com.hazelcast.durableexecutor - package com.hazelcast.durableexecutor
This package contains DurableExecutorService functionality for Hazelcast.
The DurableExecutorService extends the ExecutorService and provides additional methods like executing tasks on a member who is owner of a specific key.
com.hazelcast.durableexecutor.impl - package com.hazelcast.durableexecutor.impl
Contains the DurableExecutorService implementation classes.
com.hazelcast.durableexecutor.impl.operations - package com.hazelcast.durableexecutor.impl.operations
This package contains operations for the DurableExecutorService.
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.operations - package com.hazelcast.executor.impl.operations
This package contains operations for the IExecutorService.
com.hazelcast.flakeidgen - package com.hazelcast.flakeidgen
This package contains Flake ID Generator functionality for Hazelcast.
com.hazelcast.flakeidgen.impl - package com.hazelcast.flakeidgen.impl
 
com.hazelcast.flakeidgen.impl.client - package com.hazelcast.flakeidgen.impl.client
 
com.hazelcast.hotrestart - package com.hazelcast.hotrestart
This package contains Hot Restart classes needed for open source Hazelcast code
com.hazelcast.instance - package com.hazelcast.instance
This package contains Hazelcast Instance functionality.
com.hazelcast.instance.impl - package com.hazelcast.instance.impl
 
com.hazelcast.internal - package com.hazelcast.internal
Contains the internal packages of Hazelcast.
com.hazelcast.internal.adapter - package com.hazelcast.internal.adapter
Data structure adapters for Near Cache.
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.auditlog - package com.hazelcast.internal.auditlog
 
com.hazelcast.internal.auditlog.impl - package com.hazelcast.internal.auditlog.impl
 
com.hazelcast.internal.cluster - package com.hazelcast.internal.cluster
Contains the internals for cluster management like discovery, joining etc.
com.hazelcast.internal.cluster.fd - package com.hazelcast.internal.cluster.fd
Contains failure detector mechanism and its implementations.
com.hazelcast.internal.cluster.impl - package com.hazelcast.internal.cluster.impl
This package contains the implementation of the cluster functionality.
com.hazelcast.internal.cluster.impl.operations - package com.hazelcast.internal.cluster.impl.operations
This package contains operations for the com.hazelcast.cluster.impl package.
com.hazelcast.internal.config - package com.hazelcast.internal.config
Contains functionality for Hazelcast configurations.
com.hazelcast.internal.config.yaml - package com.hazelcast.internal.config.yaml
Contains adapter and utility classes needed to adapt YAML DOM classes as W3C DOM ones, making config builders that accept W3C DOM able to build the config structure from YAML.
com.hazelcast.internal.crdt - package com.hazelcast.internal.crdt
This package contains CRDT (conflict-free replicated data type) implementations based on the Hazelcast infrastructure.
com.hazelcast.internal.crdt.pncounter - package com.hazelcast.internal.crdt.pncounter
This package contains the PN (Positive-Negative) CRDT counter implementation.
com.hazelcast.internal.crdt.pncounter.operations - package com.hazelcast.internal.crdt.pncounter.operations
Contains the operations for the PNCounter member-side implementation.
com.hazelcast.internal.diagnostics - package com.hazelcast.internal.diagnostics
Contains functionality what is happening in a HazelcastInstance.
com.hazelcast.internal.dynamicconfig - package com.hazelcast.internal.dynamicconfig
Classes related to Dynamic Configuration.
com.hazelcast.internal.dynamicconfig.search - package com.hazelcast.internal.dynamicconfig.search
Classes related to Config Search.
com.hazelcast.internal.eviction - package com.hazelcast.internal.eviction
Eviction policy implementations.
com.hazelcast.internal.eviction.impl - package com.hazelcast.internal.eviction.impl
Eviction implementations.
com.hazelcast.internal.eviction.impl.comparator - package com.hazelcast.internal.eviction.impl.comparator
EvictionPolicyComparator implementations.
com.hazelcast.internal.eviction.impl.evaluator - package com.hazelcast.internal.eviction.impl.evaluator
com.hazelcast.internal.eviction.EvictionPolicyEvaluator implementations.
com.hazelcast.internal.eviction.impl.strategy - package com.hazelcast.internal.eviction.impl.strategy
com.hazelcast.internal.eviction.EvictionStrategy implementations.
com.hazelcast.internal.eviction.impl.strategy.sampling - package com.hazelcast.internal.eviction.impl.strategy.sampling
Sampling based com.hazelcast.internal.eviction.EvictionStrategy implementations for cache.
com.hazelcast.internal.hotrestart - package com.hazelcast.internal.hotrestart
 
com.hazelcast.internal.jmx - package com.hazelcast.internal.jmx
Contains Hazelcast management bean classes.
com.hazelcast.internal.jmx.suppliers - package com.hazelcast.internal.jmx.suppliers
Contains Hazelcast management bean stat providers.
com.hazelcast.internal.journal - package com.hazelcast.internal.journal
This package contains supporting classes for data structure specific event journals.
com.hazelcast.internal.json - package com.hazelcast.internal.json
 
com.hazelcast.internal.locksupport - package com.hazelcast.internal.locksupport
This package contains locking support for other Hazelcast data structures, such as IMap and MultiMap.
com.hazelcast.internal.locksupport.operations - package com.hazelcast.internal.locksupport.operations
This package contains the operations for the Lock support.
com.hazelcast.internal.longregister - package com.hazelcast.internal.longregister
This package contains LongRegister implementation.
com.hazelcast.internal.longregister.client - package com.hazelcast.internal.longregister.client
 
com.hazelcast.internal.longregister.client.codec - package com.hazelcast.internal.longregister.client.codec
 
com.hazelcast.internal.longregister.client.task - package com.hazelcast.internal.longregister.client.task
Client protocol tasks implementations for AtomicLong
com.hazelcast.internal.longregister.operations - package com.hazelcast.internal.longregister.operations
This package contains the operations on the LongRegister.
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.events - package com.hazelcast.internal.management.events
 
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.memory - package com.hazelcast.internal.memory
SPI that deals with memory operations.
com.hazelcast.internal.memory.impl - package com.hazelcast.internal.memory.impl
Internal memory management API implementations
com.hazelcast.internal.metrics - package com.hazelcast.internal.metrics
Contains the Hazelcast Metrics.
com.hazelcast.internal.metrics.collectors - package com.hazelcast.internal.metrics.collectors
Contains the MetricsCollector API.
com.hazelcast.internal.metrics.impl - package com.hazelcast.internal.metrics.impl
Contains the MetricsRegistry implementation.
com.hazelcast.internal.metrics.jmx - package com.hazelcast.internal.metrics.jmx
 
com.hazelcast.internal.metrics.managementcenter - package com.hazelcast.internal.metrics.managementcenter
 
com.hazelcast.internal.metrics.metricsets - package com.hazelcast.internal.metrics.metricsets
Contains all kinds of metric packs.
com.hazelcast.internal.nearcache - package com.hazelcast.internal.nearcache
Near Cache support.
com.hazelcast.internal.nearcache.impl - package com.hazelcast.internal.nearcache.impl
Near Cache implementations.
com.hazelcast.internal.nearcache.impl.invalidation - package com.hazelcast.internal.nearcache.impl.invalidation
Invalidations for Near Cache.
com.hazelcast.internal.nearcache.impl.maxsize - package com.hazelcast.internal.nearcache.impl.maxsize
Max-Size policy implementations for Near Cache.
com.hazelcast.internal.nearcache.impl.preloader - package com.hazelcast.internal.nearcache.impl.preloader
Near Cache pre-loader implementation.
com.hazelcast.internal.nearcache.impl.record - package com.hazelcast.internal.nearcache.impl.record
Near Cache record implementations.
com.hazelcast.internal.nearcache.impl.store - package com.hazelcast.internal.nearcache.impl.store
Near Cache store implementations.
com.hazelcast.internal.networking - package com.hazelcast.internal.networking
Contains the socket connection functionality.
com.hazelcast.internal.networking.nio - package com.hazelcast.internal.networking.nio
Contains the non blocking Networking functionality.
com.hazelcast.internal.networking.nio.iobalancer - package com.hazelcast.internal.networking.nio.iobalancer
Contains Handler Migration classes
com.hazelcast.internal.nio - package com.hazelcast.internal.nio
 
com.hazelcast.internal.nio.ascii - package com.hazelcast.internal.nio.ascii
Contains SocketTextReader and SocketTextWriter classes;
com.hazelcast.internal.nio.tcp - package com.hazelcast.internal.nio.tcp
Contains functionality for the TCP/IP Networking for cluster members
This whole package is internal and no compatibility will be provided.
com.hazelcast.internal.partition - package com.hazelcast.internal.partition
Contains the internals for partition assignment/management, migration, replication etc.
com.hazelcast.internal.partition.impl - package com.hazelcast.internal.partition.impl
Contains the actual implementation of the InternalPartitionService.
com.hazelcast.internal.partition.operation - package com.hazelcast.internal.partition.operation
Contains the operations for partition package.
com.hazelcast.internal.serialization - package com.hazelcast.internal.serialization
Contains the private serialization API + implementation.
com.hazelcast.internal.serialization.impl - package com.hazelcast.internal.serialization.impl
 
com.hazelcast.internal.serialization.impl.bufferpool - package com.hazelcast.internal.serialization.impl.bufferpool
Contains the logic for the BufferPool.
com.hazelcast.internal.services - package com.hazelcast.internal.services
Provides interfaces/classes for building distributed data structures and services.
com.hazelcast.internal.usercodedeployment - package com.hazelcast.internal.usercodedeployment
Module related to User Code Deployment
com.hazelcast.internal.usercodedeployment.impl - package com.hazelcast.internal.usercodedeployment.impl
 
com.hazelcast.internal.usercodedeployment.impl.filter - package com.hazelcast.internal.usercodedeployment.impl.filter
 
com.hazelcast.internal.usercodedeployment.impl.operation - package com.hazelcast.internal.usercodedeployment.impl.operation
 
com.hazelcast.internal.util - package com.hazelcast.internal.util
This package contains classes to support the inner workings of Hazelcast as well as some backports of newer Java features / data structures to support older Java versions in a clean and nice way.
com.hazelcast.internal.util.collection - package com.hazelcast.internal.util.collection
Primitive-typed collections.
com.hazelcast.internal.util.comparators - package com.hazelcast.internal.util.comparators
Provides various comparator implementations.
com.hazelcast.internal.util.concurrent - package com.hazelcast.internal.util.concurrent
Concurrent queues etc.
com.hazelcast.internal.util.counters - package com.hazelcast.internal.util.counters
Provides various counter implementations.
com.hazelcast.internal.util.executor - package com.hazelcast.internal.util.executor
This package contains classes related to Util.Executor
com.hazelcast.internal.util.filter - package com.hazelcast.internal.util.filter
Provides various Filter
com.hazelcast.internal.util.function - package com.hazelcast.internal.util.function
Backport of Java 8 functional interfaces which Agrona depends on.
com.hazelcast.internal.util.futures - package com.hazelcast.internal.util.futures
Re-usable implementations of Futures.
com.hazelcast.internal.util.hashslot - package com.hazelcast.internal.util.hashslot
Contains a family of interfaces that provide a common base for various kinds of open-addressed hashtable implementations.
com.hazelcast.internal.util.hashslot.impl - package com.hazelcast.internal.util.hashslot.impl
 
com.hazelcast.internal.util.iterator - package com.hazelcast.internal.util.iterator
Re-usable implementations of Iterators.
com.hazelcast.internal.util.scheduler - package com.hazelcast.internal.util.scheduler
This package contains scheduler classes for Util
com.hazelcast.internal.util.sort - package com.hazelcast.internal.util.sort
General API for sorting.
com.hazelcast.internal.yaml - package com.hazelcast.internal.yaml
Contains classes for loading, parsing YAML documents and building a YAML specific DOM of YamlNode instances
com.hazelcast.json - package com.hazelcast.json
Contains Json interface
com.hazelcast.json.internal - package com.hazelcast.json.internal
This package contains JsonSchema related functionality
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 commons logging, so that different logging frameworks like log4j, can be hooked in.
com.hazelcast.logging.impl - package com.hazelcast.logging.impl
 
com.hazelcast.map - package com.hazelcast.map
Contains Hazelcast map module classes.
com.hazelcast.map.eviction - package com.hazelcast.map.eviction
This package contains eviction specific classes.
com.hazelcast.map.impl - package com.hazelcast.map.impl
Contains implementation specific classes of com.hazelcast.map package.
com.hazelcast.map.impl.client - package com.hazelcast.map.impl.client
 
com.hazelcast.map.impl.event - package com.hazelcast.map.impl.event
 
com.hazelcast.map.impl.eviction - package com.hazelcast.map.impl.eviction
This package contains eviction classes.
com.hazelcast.map.impl.iterator - package com.hazelcast.map.impl.iterator
 
com.hazelcast.map.impl.journal - package com.hazelcast.map.impl.journal
 
com.hazelcast.map.impl.mapstore - package com.hazelcast.map.impl.mapstore
Contains map store operations.
com.hazelcast.map.impl.mapstore.writebehind - package com.hazelcast.map.impl.mapstore.writebehind
Package for processing write behind store operations.
com.hazelcast.map.impl.mapstore.writebehind.entry - package com.hazelcast.map.impl.mapstore.writebehind.entry
 
com.hazelcast.map.impl.mapstore.writethrough - package com.hazelcast.map.impl.mapstore.writethrough
Package for processing write through store operations.
com.hazelcast.map.impl.nearcache - package com.hazelcast.map.impl.nearcache
Contains Near Cache specific classes.
com.hazelcast.map.impl.nearcache.invalidation - package com.hazelcast.map.impl.nearcache.invalidation
 
com.hazelcast.map.impl.operation - package com.hazelcast.map.impl.operation
Package for map operations.
com.hazelcast.map.impl.proxy - package com.hazelcast.map.impl.proxy
Contains map proxy implementation and support classes.
com.hazelcast.map.impl.query - package com.hazelcast.map.impl.query
 
com.hazelcast.map.impl.querycache - package com.hazelcast.map.impl.querycache
Contains query cache internal implementation classes.
com.hazelcast.map.impl.querycache.accumulator - package com.hazelcast.map.impl.querycache.accumulator
Contains Accumulator specific classes.
com.hazelcast.map.impl.querycache.event - package com.hazelcast.map.impl.querycache.event
This package contains classes for query cache events.
com.hazelcast.map.impl.querycache.event.sequence - package com.hazelcast.map.impl.querycache.event.sequence
This package contains classes which are used to give sequence numbers to events.
com.hazelcast.map.impl.querycache.publisher - package com.hazelcast.map.impl.querycache.publisher
This package contains classes which are used for QueryCache event publishing side.
com.hazelcast.map.impl.querycache.subscriber - package com.hazelcast.map.impl.querycache.subscriber
This package contains classes which are used for QueryCache event subscription side.
com.hazelcast.map.impl.querycache.subscriber.operation - package com.hazelcast.map.impl.querycache.subscriber.operation
This package contains Enterprise specific operations for QueryCache.
com.hazelcast.map.impl.querycache.subscriber.record - package com.hazelcast.map.impl.querycache.subscriber.record
This package contains classes for QueryCacheRecord.
com.hazelcast.map.impl.querycache.utils - package com.hazelcast.map.impl.querycache.utils
Contains utility classes for QueryCache implementation.
com.hazelcast.map.impl.record - package com.hazelcast.map.impl.record
Contains record specific classes.
com.hazelcast.map.impl.recordstore - package com.hazelcast.map.impl.recordstore
 
com.hazelcast.map.impl.tx - package com.hazelcast.map.impl.tx
Contains implementation classes for TransactionalMap
com.hazelcast.map.impl.wan - package com.hazelcast.map.impl.wan
Contains wan replication event classes
com.hazelcast.map.journal - package com.hazelcast.map.journal
Contains EventJournal event interface for IMap.
com.hazelcast.map.listener - package com.hazelcast.map.listener
Contains various MapListener interfaces.
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 - package com.hazelcast.multimap
Contains the API for the MultiMap.
com.hazelcast.multimap.impl - package com.hazelcast.multimap.impl
Contains classes 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.serialization - package com.hazelcast.nio.serialization
Contains interfaces/classes related to serialization; such as serializer interfaces, input/output streams.
com.hazelcast.nio.serialization.impl - package com.hazelcast.nio.serialization.impl
 
com.hazelcast.nio.ssl - package com.hazelcast.nio.ssl
Contains interfaces/classes related to SSL for New IO
com.hazelcast.osgi - package com.hazelcast.osgi
This package contains the OSGI functionality contract points for Hazelcast.
com.hazelcast.osgi.impl - package com.hazelcast.osgi.impl
This package contains the OSGI functionality implementations for Hazelcast.
com.hazelcast.partition - package com.hazelcast.partition
Contains the partition logic for Hazelcast.
com.hazelcast.partition.membergroup - package com.hazelcast.partition.membergroup
todo
com.hazelcast.partition.strategy - package com.hazelcast.partition.strategy
Packages contains different partitioning strategies.
com.hazelcast.projection - package com.hazelcast.projection
Contains classes related to projections.
com.hazelcast.projection.impl - package com.hazelcast.projection.impl
 
com.hazelcast.query - package com.hazelcast.query
Contains interfaces/classes related to Hazelcast query and indexing support.
com.hazelcast.query.extractor - package com.hazelcast.query.extractor
Contains classes related to custom attributes and the extraction of their values.
com.hazelcast.query.impl - package com.hazelcast.query.impl
Contains the implementation classes of the query functionality.
com.hazelcast.query.impl.getters - package com.hazelcast.query.impl.getters
Helper classes for extractions of values from object instances.
com.hazelcast.query.impl.predicates - package com.hazelcast.query.impl.predicates
 
com.hazelcast.replicatedmap - package com.hazelcast.replicatedmap
Classes for replicated map.
com.hazelcast.replicatedmap.impl - package com.hazelcast.replicatedmap.impl
This package contains the implementation of the replicated map service itself and some connection interfaces only used internally.
com.hazelcast.replicatedmap.impl.client - package com.hazelcast.replicatedmap.impl.client
This package contains classes for client communication on replicated map implementation
com.hazelcast.replicatedmap.impl.operation - package com.hazelcast.replicatedmap.impl.operation
This package contains replicated map operations which are executed on remote nodes
com.hazelcast.replicatedmap.impl.record - package com.hazelcast.replicatedmap.impl.record
This package contains the implementation of the backing data storage for the replicated map implementation
com.hazelcast.ringbuffer - package com.hazelcast.ringbuffer
Contains the API for the Ringbuffer.
com.hazelcast.ringbuffer.impl - package com.hazelcast.ringbuffer.impl
Contains the Ringbuffer implementation classes.
com.hazelcast.ringbuffer.impl.client - package com.hazelcast.ringbuffer.impl.client
 
com.hazelcast.ringbuffer.impl.operations - package com.hazelcast.ringbuffer.impl.operations
 
com.hazelcast.scheduledexecutor - package com.hazelcast.scheduledexecutor
This package contains ScheduledExecutorService functionality for Hazelcast.
com.hazelcast.scheduledexecutor.impl - package com.hazelcast.scheduledexecutor.impl
 
com.hazelcast.scheduledexecutor.impl.operations - package com.hazelcast.scheduledexecutor.impl.operations
 
com.hazelcast.security - package com.hazelcast.security
Provides interfaces/classes for Hazelcast security implementation.
com.hazelcast.security.jsm - package com.hazelcast.security.jsm
Contains Java Security Manager permissions.
com.hazelcast.security.permission - package com.hazelcast.security.permission
Contains Hazelcast client permissions.
com.hazelcast.spi - package com.hazelcast.spi
Contains functionality for the Hazelcast SPI
com.hazelcast.spi.annotation - package com.hazelcast.spi.annotation
Contains annotations for Hazelcast SPI.
com.hazelcast.spi.discovery - package com.hazelcast.spi.discovery
This package contains the public SPI for vendors and users to implement their custom node / IP discovery strategy.
com.hazelcast.spi.discovery.impl - package com.hazelcast.spi.discovery.impl
 
com.hazelcast.spi.discovery.integration - package com.hazelcast.spi.discovery.integration
This package contains the public part of the integrators SPI and is meant for people that integrate Hazelcast into their own systems or frameworks and cannot use the default discovery service implementation (for example using a different DiscoveryStrategy lookup strategy like OSGi).
com.hazelcast.spi.discovery.multicast - package com.hazelcast.spi.discovery.multicast
Contains the hazelcast multicast plugin classes
com.hazelcast.spi.discovery.multicast.impl - package com.hazelcast.spi.discovery.multicast.impl
 
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
Contains the code for the EventService.
com.hazelcast.spi.impl.eventservice.impl - package com.hazelcast.spi.impl.eventservice.impl
Contains the code for the EventService implementation.
com.hazelcast.spi.impl.eventservice.impl.operations - package com.hazelcast.spi.impl.eventservice.impl.operations
Contains the operations for the EventServiceImpl.
com.hazelcast.spi.impl.executionservice - package com.hazelcast.spi.impl.executionservice
Contains the API for the ExecutionService.
com.hazelcast.spi.impl.executionservice.impl - package com.hazelcast.spi.impl.executionservice.impl
Contains the implementation of the ExecutionService.
com.hazelcast.spi.impl.merge - package com.hazelcast.spi.impl.merge
This package contains split-brain related classes.
com.hazelcast.spi.impl.operationexecutor - package com.hazelcast.spi.impl.operationexecutor
Contains the OperationRunner code.
com.hazelcast.spi.impl.operationexecutor.impl - package com.hazelcast.spi.impl.operationexecutor.impl
Contains the OperationExecutorImpl code.
com.hazelcast.spi.impl.operationexecutor.slowoperationdetector - package com.hazelcast.spi.impl.operationexecutor.slowoperationdetector
Contains the functionality to detect slow running operations using the OperationRunner instances from the OperationExecutor.
com.hazelcast.spi.impl.operationparker - package com.hazelcast.spi.impl.operationparker
Contains the internal API code for the OperationParker.
com.hazelcast.spi.impl.operationparker.impl - package com.hazelcast.spi.impl.operationparker.impl
Contains the implementation code for the OperationParker.
com.hazelcast.spi.impl.operationservice - package com.hazelcast.spi.impl.operationservice
Contains the com.hazelcast.spi.impl.operationservice.InternalOperationService API.
com.hazelcast.spi.impl.operationservice.impl - package com.hazelcast.spi.impl.operationservice.impl
Contains the code for the com.hazelcast.spi.impl.operationservice.InternalOperationService implementation.
com.hazelcast.spi.impl.operationservice.impl.operations - package com.hazelcast.spi.impl.operationservice.impl.operations
Contains the Operations being used by the OperationServiceImpl.
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.proxyservice - package com.hazelcast.spi.impl.proxyservice
Contains the API for the InternalProxyService.
com.hazelcast.spi.impl.proxyservice.impl - package com.hazelcast.spi.impl.proxyservice.impl
Contains the implementation of the InternalProxyService.
com.hazelcast.spi.impl.proxyservice.impl.operations - package com.hazelcast.spi.impl.proxyservice.impl.operations
Contains the operations for the ProxyServiceImpl.
com.hazelcast.spi.impl.securestore - package com.hazelcast.spi.impl.securestore
Contains classes/interfaces for the Hazelcast Secure Store SPI.
com.hazelcast.spi.impl.sequence - package com.hazelcast.spi.impl.sequence
Call ID sequence generators
com.hazelcast.spi.impl.servicemanager - package com.hazelcast.spi.impl.servicemanager
Contains the API for the ServiceManager.
com.hazelcast.spi.impl.servicemanager.impl - package com.hazelcast.spi.impl.servicemanager.impl
Contains the ServiceManager implementation.
com.hazelcast.spi.impl.tenantcontrol - package com.hazelcast.spi.impl.tenantcontrol
 
com.hazelcast.spi.merge - package com.hazelcast.spi.merge
This package contains interfaces and classes of the split-brain merging SPI.
com.hazelcast.spi.partition - package com.hazelcast.spi.partition
Contains the SPI for partition logic for Hazelcast.
com.hazelcast.spi.partitiongroup - package com.hazelcast.spi.partitiongroup
This package contains the basic SPI for the Partition Group SPI to define or configure how Hazelcast will configure and distribute backups in the cluster.
com.hazelcast.spi.properties - package com.hazelcast.spi.properties
Contains the Hazelcast properties implementation.
com.hazelcast.spi.tenantcontrol - package com.hazelcast.spi.tenantcontrol
Classes for tenant control
com.hazelcast.splitbrainprotection - package com.hazelcast.splitbrainprotection
Contains classes related to cluster split brain protection.
com.hazelcast.splitbrainprotection.impl - package com.hazelcast.splitbrainprotection.impl
Contains cluster split brain protection implementation classes.
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.spring.transaction - package com.hazelcast.spring.transaction
Contains Hazelcast transaction classes for Spring Transaction API.
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.reliable - package com.hazelcast.topic.impl.reliable
 
com.hazelcast.transaction - package com.hazelcast.transaction
Provides interfaces/classes for Hazelcast transaction support.
com.hazelcast.transaction.impl - package com.hazelcast.transaction.impl
Provides implementation for Hazelcast transaction support.
com.hazelcast.transaction.impl.operations - package com.hazelcast.transaction.impl.operations
 
com.hazelcast.transaction.impl.xa - package com.hazelcast.transaction.impl.xa
Provides implementation for Hazelcast XA transaction support.
com.hazelcast.transaction.impl.xa.operations - package com.hazelcast.transaction.impl.xa.operations
 
com.hazelcast.version - package com.hazelcast.version
This package contains classes to support the versioning API.
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.wan.impl.merkletree - package com.hazelcast.wan.impl.merkletree
This package contains Merkle tree based anti-entropy implementation
combine(Aggregator) - Method in class com.hazelcast.aggregation.Aggregator
Incorporates the intermediary result of the given aggregator to this instance of the aggregator.
combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.BigDecimalAverageAggregator
 
combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.BigDecimalSumAggregator
 
combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.BigIntegerAverageAggregator
 
combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.BigIntegerSumAggregator
 
combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.CountAggregator
 
combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.DistinctValuesAggregator
 
combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.DoubleAverageAggregator
 
combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.DoubleSumAggregator
 
combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.FixedSumAggregator
 
combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.FloatingPointSumAggregator
 
combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.IntegerAverageAggregator
 
combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.IntegerSumAggregator
 
combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.LongAverageAggregator
 
combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.LongSumAggregator
 
combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.MaxAggregator
 
combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.MaxByAggregator
 
combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.MinAggregator
 
combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.MinByAggregator
 
combine(Aggregator) - Method in class com.hazelcast.aggregation.impl.NumberAverageAggregator
 
combine(AggregationResult) - Method in class com.hazelcast.map.impl.query.AggregationResult
 
combine(QueryResult) - Method in class com.hazelcast.map.impl.query.QueryResult
 
combine(T) - Method in interface com.hazelcast.map.impl.query.Result
Combines the given result with this result modifying this result.
combineToInt(short, short) - Static method in class com.hazelcast.internal.nio.Bits
Combines two short integer values into an integer.
combineToLong(int, int) - Static method in class com.hazelcast.internal.nio.Bits
Combines two integer values into a long integer.
CommandParser - Interface in com.hazelcast.internal.ascii
 
commit(Xid, boolean) - Method in class com.hazelcast.client.impl.proxy.txn.xa.XAResourceProxy
 
commit() - Method in class com.hazelcast.transaction.impl.SuspendedTransaction
 
commit() - Method in interface com.hazelcast.transaction.impl.Transaction
 
commit() - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
commit(NodeEngine) - Method in class com.hazelcast.transaction.impl.TransactionLog
 
commit(Xid, boolean) - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
 
commit() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
 
COMMIT_ID - Static variable in class com.hazelcast.instance.GeneratedBuildProperties
 
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, BiConsumer) - Method in class com.hazelcast.transaction.impl.TransactionLog
 
commitAsync(BiConsumer) - Method in class com.hazelcast.transaction.impl.xa.XATransaction
 
commitClusterState(ClusterStateChange, Address, UUID, boolean) - Method in class com.hazelcast.internal.cluster.impl.ClusterStateManager
 
CommitClusterStateOp - Class in com.hazelcast.internal.cluster.impl.operations
 
CommitClusterStateOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.CommitClusterStateOp
 
CommitClusterStateOp(ClusterStateChange, Address, UUID, boolean) - Constructor for class com.hazelcast.internal.cluster.impl.operations.CommitClusterStateOp
 
commitGroupMembers() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Marks the last applied group members as committed.
commitIndex - Variable in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKey
 
commitIndex() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKey
Returns commit index of the operation that has not returned a response at the time of its commit.
commitIndex() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns the index of highest log entry known to be committed
commitIndex(long) - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Updates commit index
commitIndex - Variable in class com.hazelcast.cp.internal.RaftNodeMetrics
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cache.impl.CacheService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorService
 
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.cp.internal.datastructures.spi.AbstractCPMigrationAwareService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cp.internal.RaftService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.internal.longregister.LongRegisterService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.map.impl.MapService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.spi.impl.CountingMigrationAwareService
 
commitMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.partition.MigrationAwareService
Commits the migration process for this service, on both source and destination members.
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.transaction.impl.xa.XAService
 
commitMigrationOnDestination(MigrationInfo, Address) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
commitRemove(long) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
commitRemoveBackup(long) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
committedGroupMembers() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns committed group members
commitTransaction() - Method in class com.hazelcast.client.impl.proxy.txn.TransactionContextProxy
 
commitTransaction() - Method in class com.hazelcast.client.impl.proxy.txn.xa.XATransactionContextProxy
 
commitTransaction() - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
 
commitTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Commits a transaction.
compact() - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
Compact the Map backing arrays by rehashing with a capacity just larger than current size and giving consideration to the load factor.
compact() - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
Compact the Map backing arrays by rehashing with a capacity just larger than current size and giving consideration to the load factor.
compact() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
compactOrClear(ByteBuffer) - Static method in class com.hazelcast.internal.nio.IOUtil
Compacts or clears the buffer depending if bytes are remaining in the byte-buffer.
ComparableIdentifiedDataSerializable - Interface in com.hazelcast.query.impl
Defines a contract of objects that are simultaneously Comparable and IdentifiedDataSerializable.
comparableMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
comparableMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
comparableMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
comparableMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
Comparables - Class in com.hazelcast.query.impl
Provides utilities which compare and canonicalize Comparable instances.
comparator - Variable in class com.hazelcast.config.EvictionConfig
 
COMPARATOR - Static variable in class com.hazelcast.query.impl.Comparables
Provides the same comparision logic as Comparables.compare(java.lang.Comparable, java.lang.Comparable) does, but in a form of a Comparator.
comparatorClassName - Variable in class com.hazelcast.config.EvictionConfig
 
ComparatorEx<T> - Interface in com.hazelcast.internal.util.function
Serializable variant of java.util.Comparator which declares checked exception.
compare(CacheEntryView<K, V>, CacheEntryView<K, V>) - Method in class com.hazelcast.cache.CacheEvictionPolicyComparator
Compares the given EvictableEntryView instances and returns the result.
compare(Object, Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
compare(E, E) - Method in class com.hazelcast.internal.eviction.EvictionPolicyComparator
Compares the given EvictableEntryView instances and returns the result.
compare(EvictableEntryView, EvictableEntryView) - Method in class com.hazelcast.internal.eviction.impl.comparator.LFUEvictionPolicyComparator
 
compare(EvictableEntryView, EvictableEntryView) - Method in class com.hazelcast.internal.eviction.impl.comparator.LRUEvictionPolicyComparator
 
compare(EvictableEntryView, EvictableEntryView) - Method in class com.hazelcast.internal.eviction.impl.comparator.RandomEvictionPolicyComparator
 
compare(T, T) - Method in interface com.hazelcast.internal.util.function.ComparatorEx
 
compare(Comparator<Map.Entry>, IterationType, Map.Entry, Map.Entry) - Static method in class com.hazelcast.internal.util.SortingUtil
 
compare(EntryView, EntryView) - Method in class com.hazelcast.map.eviction.LFUEvictionPolicy
 
compare(EntryView, EntryView) - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
 
compare(EntryView<K, V>, EntryView<K, V>) - Method in class com.hazelcast.map.eviction.MapEvictionPolicy
compare(EntryView, EntryView) - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
 
compare(Comparable, Comparable) - Static method in class com.hazelcast.query.impl.Comparables
Compares the provided Comparable instances.
compare(Comparable, Comparable) - Static method in class com.hazelcast.query.impl.Numbers
Compares the provided Number instances.
COMPARE_AND_REMOVE - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
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_OP - Static variable in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongDataSerializerHook
 
COMPARE_AND_SET_OP - Static variable in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefDataSerializerHook
 
compareAnchor(PagingPredicate, QueryableEntry, Map.Entry<Integer, Map.Entry>) - Static method in class com.hazelcast.internal.util.SortingUtil
 
compareAndRemove(boolean, Set<Data>) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
compareAndRemove(Collection<Data>, boolean) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Compares if the queue contains the items in the dataList and removes them according to the retain parameter.
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
 
compareAndSet(long, long) - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
compareAndSet(T, T) - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
compareAndSet(long, long) - Method in interface com.hazelcast.cp.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.cp.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.cp.internal.datastructures.atomiclong.AtomicLong
 
compareAndSet(long, long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
compareAndSet(T, T) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
compareAndSet(long, long) - Method in class com.hazelcast.internal.jmx.AtomicLongMBean
 
compareAndSet(long, long) - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
compareAndSet(long, long) - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
compareAndSetAsync(long, long) - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
compareAndSetAsync(T, T) - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
compareAndSetAsync(long, long) - Method in interface com.hazelcast.cp.IAtomicLong
Atomically sets the value to the given updated value only if the current value == the expected value.
compareAndSetAsync(E, E) - Method in interface com.hazelcast.cp.IAtomicReference
Atomically sets the value to the given updated value only if the current value == the expected value.
compareAndSetAsync(long, long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
compareAndSetAsync(T, T) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
compareAndSetAsync(long, long) - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
compareAndSetAsync(long, long) - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
CompareAndSetMessageTask - Class in com.hazelcast.cp.internal.datastructures.atomiclong.client
Client message task for CompareAndSetOp
CompareAndSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.client.CompareAndSetMessageTask
 
CompareAndSetMessageTask - Class in com.hazelcast.cp.internal.datastructures.atomicref.client
Client message task for CompareAndSetOp
CompareAndSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.client.CompareAndSetMessageTask
 
CompareAndSetOp - Class in com.hazelcast.cp.internal.datastructures.atomiclong.operation
CompareAndSetOp() - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.operation.CompareAndSetOp
 
CompareAndSetOp(String, long, long) - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.operation.CompareAndSetOp
 
CompareAndSetOp - Class in com.hazelcast.cp.internal.datastructures.atomicref.operation
CompareAndSetOp() - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.operation.CompareAndSetOp
 
CompareAndSetOp(String, Data, Data) - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.operation.CompareAndSetOp
 
compareAndSetSequence(long, long) - Method in class com.hazelcast.map.impl.querycache.event.sequence.DefaultPartitionSequencer
 
compareAndSetSequence(long, long, int) - Method in class com.hazelcast.map.impl.querycache.event.sequence.DefaultSubscriberSequencerProvider
 
compareAndSetSequence(long, long) - Method in interface com.hazelcast.map.impl.querycache.event.sequence.PartitionSequencer
Atomically sets the value of sequence number for the partition.
compareAndSetSequence(long, long, int) - Method in interface com.hazelcast.map.impl.querycache.event.sequence.SubscriberSequencerProvider
Atomically sets the value of sequence number for the partition.
compareAndSwapInt(Object, long, int, int) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Compares and swaps an int value to an expected value atomically based by given object with given offset, if and only if its current value is equal to the expected value.
compareAndSwapInt(long, int, int) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Compares and swaps the given int value to the expected value atomically based in the given object with given offset if and only if its current value equals to specified expected value.
compareAndSwapInt(long, int, int) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
compareAndSwapInt(Object, long, int, int) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
compareAndSwapInt(long, int, int) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
compareAndSwapInt(Object, long, int, int) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
compareAndSwapLong(Object, long, long, long) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Compares and swaps a long value to an expected value atomically based by given object with given offset if and only if its current value equals to the expected value.
compareAndSwapLong(long, long, long) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Compares and swaps the long value to the expected value atomically based in the given object with given offset if and only if its current value equals the expected value.
compareAndSwapLong(long, long, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
compareAndSwapLong(Object, long, long, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
compareAndSwapLong(long, long, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
compareAndSwapLong(Object, long, long, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
compareAndSwapObject(Object, long, Object, Object) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Compares and swaps referenced object to expected object atomically based by given owner object at given offset if and only if its current object is the expected object.
compareAndSwapObject(long, Object, Object) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Compares and swaps the referenced object to the expected object atomically based by given owner object at given offset if and only if its current referenced object is the expected object.
compareAndSwapObject(long, Object, Object) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
compareAndSwapObject(Object, long, Object, Object) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
compareAndSwapObject(long, Object, Object) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
compareAndSwapObject(Object, long, Object, Object) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
compareDocumentPosition(Node) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
compareEx(T, T) - Method in interface com.hazelcast.internal.util.function.ComparatorEx
Exception-declaring version of Comparator.compare(T, T).
compareIntegers(int, int) - Static method in class com.hazelcast.internal.util.QuickMath
Compares two integers
compareLongs(long, long) - Static method in class com.hazelcast.internal.util.QuickMath
Compares two longs
compareTo(Delayed) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledFutureProxy
 
compareTo(CollectionItem) - Method in class com.hazelcast.collection.impl.collection.CollectionItem
 
compareTo(QueueItem) - Method in class com.hazelcast.collection.impl.queue.QueueItem
 
compareTo(CompositeValue) - Method in class com.hazelcast.query.impl.CompositeValue
 
compareTo(Delayed) - Method in class com.hazelcast.scheduledexecutor.impl.DelegatingScheduledFutureStripper
 
compareTo(Delayed) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledFutureProxy
 
compareTo(MemberVersion) - Method in class com.hazelcast.version.MemberVersion
 
compareTo(Version) - Method in class com.hazelcast.version.Version
 
compareTrees(MerkleTreeView, MerkleTreeView) - Static method in class com.hazelcast.wan.impl.merkletree.MerkleTreeUtil
Compares the provided local and the remote Merkle trees and returns the breadth-first orders of the leaves that found to be different.
comparing(Function<? super T, ? extends U>, Comparator<? super U>) - Static method in interface com.hazelcast.internal.util.function.ComparatorEx
comparing(FunctionEx<? super T, ? extends U>, ComparatorEx<? super U>) - Static method in interface com.hazelcast.internal.util.function.ComparatorEx
comparing(Function<? super T, ? extends U>) - Static method in interface com.hazelcast.internal.util.function.ComparatorEx
comparing(FunctionEx<? super T, ? extends U>) - Static method in interface com.hazelcast.internal.util.function.ComparatorEx
comparingDouble(ToDoubleFunction<? super T>) - Static method in interface com.hazelcast.internal.util.function.ComparatorEx
comparingDouble(ToDoubleFunctionEx<? super T>) - Static method in interface com.hazelcast.internal.util.function.ComparatorEx
comparingInt(ToIntFunction<? super T>) - Static method in interface com.hazelcast.internal.util.function.ComparatorEx
comparingInt(ToIntFunctionEx<? super T>) - Static method in interface com.hazelcast.internal.util.function.ComparatorEx
comparingLong(ToLongFunction<? super T>) - Static method in interface com.hazelcast.internal.util.function.ComparatorEx
comparingLong(ToLongFunctionEx<? super T>) - Static method in interface com.hazelcast.internal.util.function.ComparatorEx
Comparison - Enum in com.hazelcast.query.impl
complement() - Method in class com.hazelcast.internal.util.collection.ImmutablePartitionIdSet
 
complement() - Method in class com.hazelcast.internal.util.collection.PartitionIdSet
Mutates this set so it contains its complement with respect to the universe of all partition IDs.
CompletableFutureTask<V> - Class in com.hazelcast.internal.util.executor
 
complete(Object) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocation
 
complete(Object) - Method in class com.hazelcast.cp.internal.raft.impl.state.LeadershipTransferState
 
complete(Object) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
Can be called multiple times, but only the first answer will lead to the future getting triggered.
complete(V) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
complete(Object) - Method in class com.hazelcast.spi.impl.operationservice.impl.BaseInvocation
 
complete(Object) - Method in class com.hazelcast.spi.impl.operationservice.impl.Invocation
 
complete() - Method in class com.hazelcast.spi.impl.sequence.AbstractCallIdSequence
 
complete() - Method in interface com.hazelcast.spi.impl.sequence.CallIdSequence
Not idempotent: must be called exactly once per invocation.
complete() - Method in class com.hazelcast.spi.impl.sequence.CallIdSequenceWithoutBackpressure
 
COMPLETE_DESTROY_RAFT_GROUPS_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
COMPLETE_RAFT_GROUP_MEMBERSHIP_CHANGES_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
completeAppendRequestBackoffRound() - Method in class com.hazelcast.cp.internal.raft.impl.state.FollowerState
Completes a single round of append request backoff.
completeConstruction(PartitionIdSet) - Method in class com.hazelcast.map.impl.query.AggregationResult
 
completeConstruction(PartitionIdSet) - Method in class com.hazelcast.map.impl.query.QueryResult
 
completeConstruction(PartitionIdSet) - Method in interface com.hazelcast.map.impl.query.Result
Completes the construction of this result.
completeDestroyRaftGroups(Set<CPGroupId>) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
CompleteDestroyRaftGroupsOp - Class in com.hazelcast.cp.internal.raftop.metadata
Marks the given Raft groups as CPGroup.CPGroupStatus.DESTROYED and notifies its CP members
CompleteDestroyRaftGroupsOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.CompleteDestroyRaftGroupsOp
 
CompleteDestroyRaftGroupsOp(Set<CPGroupId>) - Constructor for class com.hazelcast.cp.internal.raftop.metadata.CompleteDestroyRaftGroupsOp
 
completedExceptionally(Throwable) - Static method in class com.hazelcast.spi.impl.InternalCompletableFuture
Creates a new InternalCompletableFuture that is completed exceptionally with the given Throwable.
completedExceptionally(Throwable, Executor) - Static method in class com.hazelcast.spi.impl.InternalCompletableFuture
Creates a new InternalCompletableFuture that is completed exceptionally with the given Throwable and uses the given Executor as default executor for next stages registered with default async methods.
completedTaskCount - Variable in class com.hazelcast.internal.management.dto.ManagedExecutorDTO
 
completedTaskCount() - Method in class com.hazelcast.internal.networking.nio.NioThread
 
completeExceptionally(Throwable) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocation
 
completeExceptionally(Throwable) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
completeExceptionally(Throwable) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
completeExceptionally(Throwable) - Method in class com.hazelcast.spi.impl.operationservice.impl.BaseInvocation
 
completeExceptionally(Throwable) - Method in class com.hazelcast.spi.impl.operationservice.impl.Invocation
 
completeExceptionallyInternal(Object) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
completeFuture(long, Object) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Completes the future registered with entryIndex.
completeFutures(CPGroupId, Collection<Long>, Object) - Method in class com.hazelcast.cp.internal.RaftService
Completes all futures registered with indices in the CP group associated with groupId.
completeFutures(CPGroupId, Collection<Map.Entry<Long, Object>>) - Method in class com.hazelcast.cp.internal.RaftService
Completes all futures registered with indices in the CP group associated with groupId.
completeLeadershipTransfer(Object) - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Completes the current leadership transfer state with the given result and clears the state
completeRaftGroupMembershipChanges(long, Map<CPGroupId, BiTuple<Long, Long>>) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
CompleteRaftGroupMembershipChangesOp - Class in com.hazelcast.cp.internal.raftop.metadata
Commits the given successfully-applied membership changes to the Metadata Raft group.
CompleteRaftGroupMembershipChangesOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.CompleteRaftGroupMembershipChangesOp
 
CompleteRaftGroupMembershipChangesOp(Map<CPGroupId, BiTuple<Long, Long>>) - Constructor for class com.hazelcast.cp.internal.raftop.metadata.CompleteRaftGroupMembershipChangesOp
 
completingCallback(CompletableFuture<U>) - Static method in class com.hazelcast.spi.impl.InternalCompletableFuture
 
completionId - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
completionId - Variable in class com.hazelcast.cache.impl.operation.MutatingCacheOperation
 
completionId - Variable in class com.hazelcast.client.impl.protocol.codec.CacheEntryProcessorCodec.RequestParameters
User generated id which shall be received as a field of the cache event upon completion of the request in the cluster.
completionId - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAndRemoveCodec.RequestParameters
User generated id which shall be received as a field of the cache event upon completion of the request in the cluster.
completionId - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAndReplaceCodec.RequestParameters
User generated id which shall be received as a field of the cache event upon completion of the request in the cluster.
completionId - Variable in class com.hazelcast.client.impl.protocol.codec.CachePutAllCodec.RequestParameters
user generated id which shall be received as a field of the cache event upon completion of the request in the cluster.
completionId - Variable in class com.hazelcast.client.impl.protocol.codec.CachePutCodec.RequestParameters
User generated id which shall be received as a field of the cache event upon completion of the request in the cluster.
completionId - Variable in class com.hazelcast.client.impl.protocol.codec.CachePutIfAbsentCodec.RequestParameters
User generated id which shall be received as a field of the cache event upon completion of the request in the cluster.
completionId - Variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllCodec.RequestParameters
User generated id which shall be received as a field of the cache event upon completion of the request in the cluster.
completionId - Variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllKeysCodec.RequestParameters
User generated id which shall be received as a field of the cache event upon completion of the request in the cluster.
completionId - Variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveCodec.RequestParameters
User generated id which shall be received as a field of the cache event upon completion of the request in the cluster.
completionId - Variable in class com.hazelcast.client.impl.protocol.codec.CacheReplaceCodec.RequestParameters
User generated id which shall be received as a field of the cache event upon completion of the request in the cluster.
compose(FunctionEx<? super V, ? extends T>) - Method in interface com.hazelcast.internal.util.function.FunctionEx
composeAttributeValueExtractionFailedMessage(Member) - Static method in class com.hazelcast.query.impl.getters.AbstractMultiValueGetter
 
ComposedKeyMap<K1,K2,V> - Class in com.hazelcast.internal.util.collection
Map with a composed key.
ComposedKeyMap() - Constructor for class com.hazelcast.internal.util.collection.ComposedKeyMap
 
ComposeNode(CompletableFuture<U>, Function<? super T, ? extends CompletionStage<U>>) - Constructor for class com.hazelcast.spi.impl.AbstractInvocationFuture.ComposeNode
 
COMPOSITE_VALUE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
CompositeConverter - Class in com.hazelcast.query.impl
Represents a composite converter composed out of a converter tuple.
CompositeConverter(TypeConverter[]) - Constructor for class com.hazelcast.query.impl.CompositeConverter
Constructs a new composite converter from the given component converters.
CompositeEqualPredicate - Class in com.hazelcast.query.impl.predicates
Does the same thing as EqualPredicate but for composite indexes and values.
CompositeEqualPredicate(InternalIndex, CompositeValue) - Constructor for class com.hazelcast.query.impl.predicates.CompositeEqualPredicate
Constructs a new composite equal predicate for the given index and composite value.
CompositeEvictionChecker - Class in com.hazelcast.internal.eviction
EvictionChecker implementation for composing results of given EvictionChecker instances.
CompositeEvictionChecker(EvictionChecker...) - Constructor for class com.hazelcast.internal.eviction.CompositeEvictionChecker
 
CompositeEvictionChecker.CompositionOperator - Enum in com.hazelcast.internal.eviction
Operator for composing results of given EvictionChecker instances.
CompositeIndexVisitor - Class in com.hazelcast.query.impl.predicates
Optimizes single-attribute predicates into composite index predicates.
CompositeIndexVisitor() - Constructor for class com.hazelcast.query.impl.predicates.CompositeIndexVisitor
 
CompositeMessageTaskFactory - Class in com.hazelcast.client.impl
 
CompositeMessageTaskFactory(NodeEngine) - Constructor for class com.hazelcast.client.impl.CompositeMessageTaskFactory
 
CompositeRangePredicate - Class in com.hazelcast.query.impl.predicates
Does the same thing as GreaterLessPredicate, BetweenPredicate and BoundedRangePredicate but for composite indexes and values.
CompositeRangePredicate(InternalIndex, CompositeValue, boolean, CompositeValue, boolean, int) - Constructor for class com.hazelcast.query.impl.predicates.CompositeRangePredicate
Constructs a new composite range predicate on the given index.
CompositeValue - Class in com.hazelcast.query.impl
Represents a composite value composed out of a value tuple called components.
CompositeValue() - Constructor for class com.hazelcast.query.impl.CompositeValue
Constructs a new composite value for the deserialization purposes.
CompositeValue(Comparable[]) - Constructor for class com.hazelcast.query.impl.CompositeValue
Constructs a new composite value from the given components.
CompositeValue(int, Comparable, Comparable) - Constructor for class com.hazelcast.query.impl.CompositeValue
Constructs a new composite value of the given width having the given prefix value as its first component and the filler value as its remaining components.
CompoundPredicate - Interface in com.hazelcast.query.impl.predicates
Interface for predicates which operate on an array of sub-predicates.
compress(byte[]) - Static method in class com.hazelcast.internal.nio.IOUtil
 
computeIfAbsent(int, IntFunction<? extends V>) - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
Get a value for a given key, or if it does ot exist then default the value via a IntFunction and put it in the map.
computeIfAbsent(long, LongFunction<? extends V>) - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
Get a value for a given key, or if it does ot exist then default the value via a LongFunction and put it in the map.
computePerturbationValue(int) - Static method in class com.hazelcast.internal.util.HashUtil
Computes the key perturbation value applied before hashing.
concat(T[], T[], T[]) - Static method in class com.hazelcast.internal.util.collection.ArrayUtils
Copies in order sourceFirst and sourceSecond into dest.
concatenate(byte[], byte[]) - Static method in class com.hazelcast.internal.ascii.memcache.MemcacheCommandProcessor
 
concurrencyDetection(ConcurrencyDetection) - Method in class com.hazelcast.internal.networking.nio.NioNetworking.Context
 
ConcurrencyDetection - Class in com.hazelcast.internal.util
Responsible for tracking if concurrency is detected.
ConcurrencyUtil - Class in com.hazelcast.internal.util
Utility methods to getOrPutSynchronized and getOrPutIfAbsent in a thread safe way from a ConcurrentMap with a ConstructorFunction.
CONCURRENT_MODIFICATION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
CONCURRENT_WINDOW_MS - Static variable in class com.hazelcast.client.properties.ClientProperty
Property needed for concurrency detection so that write through and dynamic response handling can be done correctly.
CONCURRENT_WINDOW_MS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Property needed for concurrency detection so that write through can be done correctly.
ConcurrentArrayRingbuffer<E> - Class in com.hazelcast.internal.metrics.managementcenter
 
ConcurrentArrayRingbuffer(int) - Constructor for class com.hazelcast.internal.metrics.managementcenter.ConcurrentArrayRingbuffer
 
ConcurrentArrayRingbuffer.RingbufferSlice<E> - Class in com.hazelcast.internal.metrics.managementcenter
 
ConcurrentConveyor<E> - Class in com.hazelcast.internal.util.concurrent
A many-to-one conveyor of interthread messages.
concurrentConveyor(E1, QueuedPipe<E1>...) - Static method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Creates a new concurrent conveyor.
ConcurrentConveyorException - Exception in com.hazelcast.internal.util.concurrent
Exception thrown by the ConcurrentConveyor.
ConcurrentConveyorException(String) - Constructor for exception com.hazelcast.internal.util.concurrent.ConcurrentConveyorException
 
ConcurrentConveyorException(String, Throwable) - Constructor for exception com.hazelcast.internal.util.concurrent.ConcurrentConveyorException
 
ConcurrentConveyorSingleQueue<E> - Class in com.hazelcast.internal.util.concurrent
Specialization of ConcurrentConveyor to a single queue.
concurrentConveyorSingleQueue(E1, QueuedPipe<E1>) - Static method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyorSingleQueue
Creates a new concurrent conveyor with a single queue.
ConcurrentHashMapStreamSerializer<K,V> - Class in com.hazelcast.internal.serialization.impl
The ConcurrentHashMap serializer Important Note: The ConcurrentHashMap 'loadfactor' is not serialized.
ConcurrentHashMapStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConcurrentHashMapStreamSerializer
 
ConcurrentHeapMemoryAccessor - Interface in com.hazelcast.internal.memory
Extends HeapMemoryAccessor with concurrent operations.
concurrentInvocations() - Method in class com.hazelcast.spi.impl.sequence.AbstractCallIdSequence
 
ConcurrentMemoryAccessor - Interface in com.hazelcast.internal.memory
Extension of MemoryAccessor for memory operations with concurrent semantics: volatile, ordered, and CAS.
ConcurrentReferenceHashMap<K,V> - Class in com.hazelcast.internal.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.internal.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.internal.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.internal.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.internal.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.internal.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.internal.util.ConcurrentReferenceHashMap
Creates a new, empty reference map with the specified reference types and behavioral options.
ConcurrentReferenceHashMap(int) - Constructor for class com.hazelcast.internal.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.internal.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.internal.util.ConcurrentReferenceHashMap
Creates a new map with the same mappings as the given map.
ConcurrentReferenceHashMap.Option - Enum in com.hazelcast.internal.util
Behavior-changing configuration options for the map
ConcurrentReferenceHashMap.ReferenceType - Enum in com.hazelcast.internal.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.internal.util
 
ConcurrentReferenceHashMap.WriteThroughEntry - Class in com.hazelcast.internal.util
Custom Entry class used by EntryIterator.next(), that relays setValue changes to the underlying map.
concurrentSetOfValues(Set<V>) - Static method in class com.hazelcast.cache.impl.DeferredValue
 
ConcurrentSkipListMapStreamSerializer<K,V> - Class in com.hazelcast.internal.serialization.impl
The ConcurrentSkipListMap serializer
ConcurrentSkipListMapStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConcurrentSkipListMapStreamSerializer
 
ConcurrentSkipListSetStreamSerializer<E> - Class in com.hazelcast.internal.serialization.impl
The ConcurrentSkipListSet serializer
ConcurrentSkipListSetStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConcurrentSkipListSetStreamSerializer
 
config - Variable in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxySupport
 
Config - Class in com.hazelcast.config
Contains all the configuration to start a HazelcastInstance.
Config() - Constructor for class com.hazelcast.config.Config
 
Config(String) - Constructor for class com.hazelcast.config.Config
 
config - Variable in class com.hazelcast.instance.impl.Node
 
config - Variable in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
config - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
config - Variable in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
config - Variable in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
 
CONFIG_CHECK - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
CONFIG_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
CONFIG_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
CONFIG_MISMATCH - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
CONFIG_MISMATCH - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
CONFIG_PUBLISH_MAX_ATTEMPT_COUNT - Static variable in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
ConfigAccessor - Class in com.hazelcast.config
Private API for accessing configuration at runtime
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.internal.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.internal.cluster.impl.ConfigCheck
 
ConfigCheck(Config, String) - Constructor for class com.hazelcast.internal.cluster.impl.ConfigCheck
 
configCheck - Variable in class com.hazelcast.internal.cluster.impl.JoinMessage
 
ConfigCheckMode - Enum in com.hazelcast.internal.dynamicconfig
Behaviour when detects a configuration conflict while registering a new dynamic configuraiton.
ConfigDataSerializerHook - Class in com.hazelcast.config
DataSerializerHook for com.hazelcast.config classes
ConfigDataSerializerHook() - Constructor for class com.hazelcast.config.ConfigDataSerializerHook
 
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.internal.cluster.impl
Exception thrown when 2 nodes want to join, but there configuration doesn't match
ConfigMismatchException(String) - Constructor for exception com.hazelcast.internal.cluster.impl.ConfigMismatchException
 
ConfigMismatchOp - Class in com.hazelcast.internal.cluster.impl.operations
When a node wants to join the cluster, its sends its ConfigCheck to the cluster where it is validated.
ConfigMismatchOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.ConfigMismatchOp
 
ConfigMismatchOp(String) - Constructor for class com.hazelcast.internal.cluster.impl.operations.ConfigMismatchOp
 
ConfigPatternMatcher - Interface in com.hazelcast.config
The ConfigPatternMatcher provides a strategy to match an item name to a configuration pattern.
ConfigPermission - Class in com.hazelcast.security.permission
 
ConfigPermission() - Constructor for class com.hazelcast.security.permission.ConfigPermission
 
ConfigPropertiesPlugin - Class in com.hazelcast.internal.diagnostics
ConfigPropertiesPlugin(NodeEngineImpl) - Constructor for class com.hazelcast.internal.diagnostics.ConfigPropertiesPlugin
 
ConfigPropertiesPlugin(ILogger, HazelcastProperties) - Constructor for class com.hazelcast.internal.diagnostics.ConfigPropertiesPlugin
 
ConfigReplacer - Interface in com.hazelcast.config.replacer.spi
Interface to be implemented by pluggable variable replacers for the configuration files.
configs - Variable in class com.hazelcast.cache.impl.AbstractCacheService
Map from full prefixed cache name to CacheConfig
ConfigSearch - Class in com.hazelcast.internal.dynamicconfig.search
Config search factory, which allows to build searchers for the given config types.
ConfigSupplier<T extends IdentifiedDataSerializable> - Interface in com.hazelcast.internal.dynamicconfig.search
Config supplier, which helps to match type of the config to corresponding search method.
ConfigurableService<T> - Interface in com.hazelcast.internal.services
A capability for SPI services.
CONFIGURATION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
ConfigurationService - Interface in com.hazelcast.internal.dynamicconfig
Dynamic configurations.
configure(CallbackHandler) - Method in class com.hazelcast.config.security.StaticCredentialsFactory
 
configure(T) - Method in interface com.hazelcast.internal.services.ConfigurableService
 
configure(CallbackHandler) - Method in interface com.hazelcast.security.ICredentialsFactory
configure(Config, Properties) - Method in interface com.hazelcast.security.IPermissionPolicy
Configures IPermissionPolicy.
ConfigUtils - Class in com.hazelcast.internal.config
Utility class to access configuration.
ConfigValidator - Class in com.hazelcast.internal.config
Validates a Hazelcast configuration in a specific context like OS vs.
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.
ConfigXmlGenerator(boolean, boolean) - Constructor for class com.hazelcast.config.ConfigXmlGenerator
Creates a ConfigXmlGenerator.
ConfigXmlGenerator.XmlGenerator - Class in com.hazelcast.config
Utility class to build xml using a StringBuilder.
connect() - Method in class com.hazelcast.client.impl.spi.impl.ClientTransactionManagerServiceImpl
 
connect(InetSocketAddress, int) - Method in class com.hazelcast.internal.networking.AbstractChannel
 
connect(InetSocketAddress, int) - Method in interface com.hazelcast.internal.networking.Channel
Connects the channel.
CONNECT_ALL_WAIT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
connection - Variable in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
Connection - Interface in com.hazelcast.internal.nio
Represents a 'connection' between two machines.
connection - Variable in class com.hazelcast.internal.nio.tcp.PacketDecoder
 
CONNECTION_ASKS_PROTOCOL - Static variable in class com.hazelcast.internal.auditlog.impl.AuditlogTypeIds
 
CONNECTION_MONITOR_INTERVAL - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
CONNECTION_MONITOR_MAX_FAULTS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
connectionAdded(Connection) - Method in class com.hazelcast.client.impl.connection.nio.ClientICMPManager
 
connectionAdded(Connection) - Method in class com.hazelcast.client.impl.connection.nio.ClusterConnectorServiceImpl
 
connectionAdded(Connection) - Method in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
connectionAdded(Connection) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
connectionAdded(Connection) - Method in interface com.hazelcast.internal.nio.ConnectionListener
 
connectionCount - Variable in class com.hazelcast.internal.management.dto.ConnectionManagerDTO
 
connectionIdGen - Variable in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
ConnectionLifecycleListener<T extends Connection> - Interface in com.hazelcast.internal.nio
 
ConnectionListenable - Interface in com.hazelcast.internal.nio
Provides connection listen capabilities.
ConnectionListener - Interface in com.hazelcast.internal.nio
A listener for the EndpointManager to listen to connections being added or removed.
connectionManager - Variable in class com.hazelcast.client.impl.spi.impl.AbstractClientInvocationService
 
ConnectionManagerDTO - Class in com.hazelcast.internal.management.dto
A Serializable DTO for NetworkingServiceMBean.
ConnectionManagerDTO() - Constructor for class com.hazelcast.internal.management.dto.ConnectionManagerDTO
 
ConnectionManagerDTO(NetworkingService) - Constructor for class com.hazelcast.internal.management.dto.ConnectionManagerDTO
 
connectionRemoved(Connection) - Method in class com.hazelcast.client.impl.connection.nio.ClientICMPManager
 
connectionRemoved(Connection) - Method in class com.hazelcast.client.impl.connection.nio.ClusterConnectorServiceImpl
 
connectionRemoved(Connection) - Method in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
connectionRemoved(Connection) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
connectionRemoved(Connection) - Method in interface com.hazelcast.internal.nio.ConnectionListener
 
ConnectionRetryConfig - Class in com.hazelcast.client.config
Connection Retry Config is controls the period among the retries and when should a client gave up retrying.
ConnectionRetryConfig() - Constructor for class com.hazelcast.client.config.ConnectionRetryConfig
 
ConnectionRetryConfig(ConnectionRetryConfig) - Constructor for class com.hazelcast.client.config.ConnectionRetryConfig
 
ConnectionType - Enum in com.hazelcast.internal.nio
An enumeration of all possible Connection types.
connectToCluster() - Method in interface com.hazelcast.client.impl.connection.nio.ClusterConnectorService
 
connectToCluster() - Method in class com.hazelcast.client.impl.connection.nio.ClusterConnectorServiceImpl
 
connectToClusterAsync() - Method in interface com.hazelcast.client.impl.connection.nio.ClusterConnectorService
 
connectToClusterAsync() - Method in class com.hazelcast.client.impl.connection.nio.ClusterConnectorServiceImpl
 
CONSISTENCY_LOST_EXCEPTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
consistencyCheck(String, String, String) - Method in interface com.hazelcast.wan.impl.WanReplicationService
Initiate WAN consistency check for a specific map.
consistencyCheck(String, String, String) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
 
ConsistencyCheckResult - Class in com.hazelcast.wan
Result of the last WAN consistency check result.
ConsistencyCheckResult(UUID) - Constructor for class com.hazelcast.wan.ConsistencyCheckResult
 
ConsistencyCheckResult(UUID, int, int, int, int, int) - Constructor for class com.hazelcast.wan.ConsistencyCheckResult
Constructs the result of the WAN consistency check comparison
ConsistencyCheckStrategy - Enum in com.hazelcast.config
Strategy for checking the consistency of data between replicas.
ConsistencyLostException - Exception in com.hazelcast.core
Exception that indicates that the consistency guarantees provided by some service has been lost.
ConsistencyLostException(String) - Constructor for exception com.hazelcast.core.ConsistencyLostException
 
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
 
ConsoleRequest - Interface in com.hazelcast.internal.management.request
Represents request sent from Management Center.
ConsoleRequestConstants - Class in com.hazelcast.internal.management.request
Constants to identify serialized requests.
CONSTANT_SERIALIZERS_LENGTH - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_BOOLEAN - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_BOOLEAN_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_BYTE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_BYTE_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_CHAR - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_CHAR_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_DATA_SERIALIZABLE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_DOUBLE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_DOUBLE_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_FLOAT - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_FLOAT_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_INTEGER - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_INTEGER_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_LONG - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_LONG_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_NULL - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_PORTABLE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_SHORT - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_SHORT_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_STRING - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_STRING_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
CONSTANT_TYPE_UUID - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
ConstantSerializers - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.BooleanArraySerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.BooleanSerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.ByteSerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.CharArraySerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.CharSerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.DoubleArraySerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.DoubleSerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.FloatArraySerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.FloatSerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.IntegerArraySerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.IntegerSerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.LongArraySerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.LongSerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.NullSerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.ShortArraySerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.ShortSerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.StringArraySerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.StringSerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.TheByteArraySerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstantSerializers.UuidSerializer - Class in com.hazelcast.internal.serialization.impl
 
ConstructorFunction<K,V> - Interface in com.hazelcast.internal.util
See ConcurrencyUtil
constructPath(YamlNode, String) - Static method in class com.hazelcast.internal.yaml.YamlUtil
Constructs the path of the node with the provided parent node and nodeName.
ConsumeAccumulatorOperation - Class in com.hazelcast.map.impl.querycache.accumulator
Processes remaining items in Accumulator instances on a partition.
ConsumeAccumulatorOperation() - Constructor for class com.hazelcast.map.impl.querycache.accumulator.ConsumeAccumulatorOperation
 
ConsumeAccumulatorOperation(Queue<Accumulator>, int) - Constructor for class com.hazelcast.map.impl.querycache.accumulator.ConsumeAccumulatorOperation
 
consumeDouble(String, double) - Method in interface com.hazelcast.internal.metrics.managementcenter.MetricConsumer
Called when the Metric contains a double value.
consumeLong(String, long) - Method in interface com.hazelcast.internal.metrics.managementcenter.MetricConsumer
Called when the Metric contains a long value.
ConsumerEx<T> - Interface in com.hazelcast.internal.util.function
Serializable variant of java.util.function.Consumer which declares checked exception.
container - Variable in class com.hazelcast.collection.impl.queue.QueueItem
 
containerIterator(int) - Method in class com.hazelcast.spi.impl.merge.AbstractContainerCollector
Returns all containers of the data structure for the given partition ID.
containerIterator(int) - Method in class com.hazelcast.spi.impl.merge.AbstractNamedContainerCollector
 
containers - Variable in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
containers - Variable in class com.hazelcast.spi.impl.merge.AbstractNamedContainerCollector
 
contains(Object) - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
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(T) - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
contains(Object) - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
contains(Object) - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
contains(Object) - Method in class com.hazelcast.client.impl.proxy.ClientSetProxy
 
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
Checks if the queue contains all items in the dataSet.
CONTAINS - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
contains(Object) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
contains(E) - Method in interface com.hazelcast.cp.IAtomicReference
Checks if the reference contains the value.
contains(Data) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRef
 
contains(T) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
contains(Object) - Method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
 
contains(T[], T) - Static method in class com.hazelcast.internal.util.collection.ArrayUtils
 
contains(Object) - Method in class com.hazelcast.internal.util.collection.InflatableSet
 
contains(Object) - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap.KeySet
 
contains(int) - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap.KeySet
Non-boxing variant of contains().
contains(Object) - Method in class com.hazelcast.internal.util.collection.IntHashSet
 
contains(int) - Method in class com.hazelcast.internal.util.collection.IntHashSet
 
contains(Object) - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap.KeySet
 
contains(long) - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap.KeySet
Non-boxing variant of contains().
contains(Object) - Method in class com.hazelcast.internal.util.collection.LongHashSet
contains(long) - Method in class com.hazelcast.internal.util.collection.LongHashSet
contains(long) - Method in interface com.hazelcast.internal.util.collection.LongSet
 
contains(long) - Method in class com.hazelcast.internal.util.collection.LongSetHsa
 
contains(Object) - Method in class com.hazelcast.internal.util.collection.MapDelegatingSet
contains(Object) - Method in class com.hazelcast.internal.util.collection.OAHashSet
 
contains(Object, int) - Method in class com.hazelcast.internal.util.collection.OAHashSet
Returns true if this set contains the specified element with the hash provided in parameter.
contains(Object) - Method in class com.hazelcast.internal.util.collection.PartitionIdSet
 
contains(int) - Method in class com.hazelcast.internal.util.collection.PartitionIdSet
 
contains(Object) - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
Legacy method testing if some key maps into the specified value in this table.
contains(E) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
Checks whether an element exist in this queue.
CONTAINS - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
contains(Object) - Method in class com.hazelcast.query.impl.AndResultSet
 
contains(Object) - Method in class com.hazelcast.query.impl.DuplicateDetectingMultiResult
 
contains(Object) - Method in class com.hazelcast.query.impl.FastMultiResultSet
 
contains(Object) - Method in class com.hazelcast.query.impl.OrResultSet
 
contains(Object) - Method in class com.hazelcast.query.impl.SingleResultSet
 
CONTAINS_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
CONTAINS_ENTRY - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
CONTAINS_KEY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CONTAINS_KEY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
CONTAINS_KEY - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
CONTAINS_OP - Static variable in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefDataSerializerHook
 
CONTAINS_VALUE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
CONTAINS_VALUE - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
CONTAINS_VALUE_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
containsAddress(Address) - Method in class com.hazelcast.internal.cluster.impl.MembersView
 
containsAll(Collection<?>) - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
containsAll(Collection<?>) - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
containsAll(Collection<?>) - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
containsAll(Collection<?>) - Method in class com.hazelcast.client.impl.proxy.ClientSetProxy
 
containsAll(Collection<?>) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
containsAll(Collection<?>) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
containsAll(Collection<?>) - Method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
 
containsAll(Collection<?>) - Method in class com.hazelcast.internal.util.collection.IntHashSet
 
containsAll(IntHashSet) - Method in class com.hazelcast.internal.util.collection.IntHashSet
IntHashSet specialised variant of {this#containsAll(Collection)}.
containsAll(Collection<?>) - Method in class com.hazelcast.internal.util.collection.LongHashSet
containsAll(LongHashSet) - Method in class com.hazelcast.internal.util.collection.LongHashSet
LongHashSet specialised variant of {this#containsAll(Collection)}.
containsAll(PartitionIdSet) - Method in class com.hazelcast.internal.util.collection.PartitionIdSet
 
containsAsync(T) - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
containsAsync(E) - Method in interface com.hazelcast.cp.IAtomicReference
Checks if the reference contains the value.
containsAsync(T) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
containsCounter(String) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterService
Returns true if the CRDT state for the PN counter with the given name is present on this node.
containsEntry(K, V) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
containsEntry(boolean, Data, Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
containsEntry(K, V) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
containsEntry(K, V) - Method in interface com.hazelcast.multimap.MultiMap
Returns whether the multimap contains the given key-value pair.
ContainsEntryOperation - Class in com.hazelcast.multimap.impl.operations
 
ContainsEntryOperation() - Constructor for class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
 
ContainsEntryOperation(String, Data, Data) - Constructor for class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
 
ContainsEntryOperation(String, Data, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
 
containsInternal(Data, Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
containsKey(K) - Method in class com.hazelcast.cache.impl.CacheProxy
 
containsKey(K) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
containsKey(Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
containsKey(K) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
containsKey(Object) - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
containsKey(Object) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
containsKey(K) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
containsKey(K) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
containsKey(K) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
containsKey(K) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
containsKey(K) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
containsKey(Object) - Method in class com.hazelcast.internal.dynamicconfig.AggregatingMap
 
containsKey(Object) - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
 
containsKey(int) - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
Overloaded version of Map.containsKey(Object) that takes a primitive int key.
containsKey(long) - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
Long primitive specialised containsKey.
containsKey(Object) - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
 
containsKey(long) - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
 
containsKey(long) - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
 
containsKey(Object) - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
 
containsKey(long) - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
Overloaded version of Map.containsKey(Object) that takes a primitive long key.
containsKey(Object) - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
Tests if the specified object is a key in this table.
containsKey(Object) - Method in interface com.hazelcast.map.BaseMap
Returns true if this map contains an entry for the specified key.
containsKey(Object) - Method in interface com.hazelcast.map.IMap
Returns true if this map contains an entry for the specified key.
containsKey(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
containsKey(Object) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
containsKey(Data) - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordStore
 
containsKey(Data, Address) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
containsKey(Data, Address) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
containsKey(K) - Method in interface com.hazelcast.map.impl.recordstore.Storage
 
containsKey(Data) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
containsKey(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
containsKey(Object, boolean) - 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(K) - Method in interface com.hazelcast.multimap.MultiMap
Returns whether the multimap contains an entry with the key.
containsKey(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
containsKey(Object) - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
 
containsKey(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
containsKey(Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
containsKey(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns true if value for given key is provided (either as a HazelcastProperty or a System property).
containsKey(Object) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.containsKey(Object).
containsKeyInternal(Object) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
containsKeyInternal(Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
containsKeyInternal(Object) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
containsKeyInternal(Object) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
ContainsKeyOperation - Class in com.hazelcast.map.impl.operation
 
ContainsKeyOperation() - Constructor for class com.hazelcast.map.impl.operation.ContainsKeyOperation
 
ContainsKeyOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.ContainsKeyOperation
 
ContainsKeyOperation - Class in com.hazelcast.replicatedmap.impl.operation
 
ContainsKeyOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ContainsKeyOperation
 
ContainsKeyOperation(String, Data) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ContainsKeyOperation
 
containsLogEntry(long) - Method in class com.hazelcast.cp.internal.raft.impl.log.RaftLog
Returns true if the log contains an entry at entryIndex, false otherwise.
containsMember(RaftEndpoint) - Method in class com.hazelcast.cp.internal.CPGroupInfo
 
containsMember(Address, UUID) - Method in class com.hazelcast.internal.cluster.impl.MembersView
 
ContainsMessageTask - Class in com.hazelcast.cp.internal.datastructures.atomicref.client
Client message task for ContainsOp
ContainsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.client.ContainsMessageTask
 
ContainsOp - Class in com.hazelcast.cp.internal.datastructures.atomicref.operation
ContainsOp() - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.operation.ContainsOp
 
ContainsOp(String, Data) - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.operation.ContainsOp
 
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
 
containsQueue(String) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
containsRecordId(long) - Method in class com.hazelcast.multimap.impl.MultiMapValue
 
containsRecordKey(K) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
containsRecordKey(K) - Method in class com.hazelcast.internal.nearcache.impl.store.BaseHeapNearCacheRecordStore
 
containsSpecialCharacters(String) - Static method in class com.hazelcast.internal.metrics.MetricsUtil
 
containsValue(Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
containsValue(Object) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
containsValue(Object) - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
containsValue(Object) - Method in class com.hazelcast.internal.dynamicconfig.AggregatingMap
 
containsValue(Object) - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
 
containsValue(long) - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
 
containsValue(Object) - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
 
containsValue(Object) - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
 
containsValue(Object) - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
Returns true if this map maps one or more keys to the specified value.
containsValue(Object) - Method in interface com.hazelcast.map.IMap
containsValue(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
containsValue(Object) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
containsValue(Object) - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordStore
 
containsValue(Object) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
containsValue(Object) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
containsValue(Object) - Method in interface com.hazelcast.map.QueryCache
 
containsValue(boolean, Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
containsValue(Object) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
containsValue(Object) - Method in interface com.hazelcast.multimap.MultiMap
Returns whether the multimap contains an entry with the value.
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
 
ContainsValueOperation - Class in com.hazelcast.map.impl.operation
 
ContainsValueOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.ContainsValueOperation
 
ContainsValueOperation() - Constructor for class com.hazelcast.map.impl.operation.ContainsValueOperation
 
ContainsValueOperation - Class in com.hazelcast.replicatedmap.impl.operation
 
ContainsValueOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ContainsValueOperation
 
ContainsValueOperation(String, Data) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ContainsValueOperation
 
ContainsValueOperationFactory - Class in com.hazelcast.map.impl.operation
 
ContainsValueOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.ContainsValueOperationFactory
 
ContainsValueOperationFactory(String, Data) - Constructor for class com.hazelcast.map.impl.operation.ContainsValueOperationFactory
 
content - Variable in class com.hazelcast.client.impl.protocol.ClientMessage.Frame
 
CONTENT_LENGTH - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
CONTENT_TYPE - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
CONTENT_TYPE_BINARY - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
CONTENT_TYPE_JSON - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
CONTENT_TYPE_PLAIN_TEXT - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
Context() - Constructor for class com.hazelcast.internal.networking.nio.NioNetworking.Context
 
context - Variable in class com.hazelcast.map.impl.querycache.subscriber.AbstractQueryCacheEndToEndConstructor
 
ContextMutexFactory - Class in com.hazelcast.internal.util
Provides reference-counted mutexes suitable for synchronization in the context of a supplied object.
ContextMutexFactory() - Constructor for class com.hazelcast.internal.util.ContextMutexFactory
 
ContextMutexFactory.Mutex - Class in com.hazelcast.internal.util
Reference counted mutex, which will remove itself from the mutexMap when it is no longer referenced.
ContinuousQueryAddListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ContinuousQueryAddListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
ContinuousQueryAddListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ContinuousQueryAddListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ContinuousQueryDestroyCacheCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ContinuousQueryDestroyCacheCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ContinuousQueryDestroyCacheCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ContinuousQueryMadePublishableCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ContinuousQueryMadePublishableCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ContinuousQueryMadePublishableCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ContinuousQueryPublisherCreateCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ContinuousQueryPublisherCreateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ContinuousQueryPublisherCreateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ContinuousQueryPublisherCreateWithValueCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ContinuousQueryPublisherCreateWithValueCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ContinuousQueryPublisherCreateWithValueCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ContinuousQuerySetReadCursorCodec - Class in com.hazelcast.client.impl.protocol.codec
This method can be used to recover from a possible event loss situation.
ContinuousQuerySetReadCursorCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ContinuousQuerySetReadCursorCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
convert(Comparable) - Method in interface com.hazelcast.core.TypeConverter
Compares a Comparable typed value to another one.
convert(long, MemoryUnit) - Method in enum com.hazelcast.memory.MemoryUnit
 
convert(Comparable) - Method in class com.hazelcast.query.impl.CompositeConverter
 
convert(Comparable, Comparable) - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
Converts givenAttributeValue to the type of entryAttributeValue Good practice: do not invoke this method if entryAttributeValue == null
convert(Comparable) - Method in class com.hazelcast.query.impl.TypeConverters.BaseTypeConverter
 
convertData(Data, DataType) - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1
 
convertData(Data, DataType) - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
 
ConverterCache - Class in com.hazelcast.query.impl
Maintains a cache of TypeConverter instances corresponding to attributes of a single Indexes instance.
ConverterCache(Indexes) - Constructor for class com.hazelcast.query.impl.ConverterCache
Constructs a new converters cache for the given indexes.
convertFromJsonValue(JsonValue) - Static method in class com.hazelcast.query.impl.getters.AbstractJsonGetter
Converts a JsonValue object to its corresponding Java object.
convertToEventType(CacheEventType) - Static method in enum com.hazelcast.cache.CacheEventType
Converts a CacheEventType into EventType.
convertToInputStream(DataInput, int) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
 
convertToLetter(int) - Method in class com.hazelcast.internal.util.PhoneHome
 
copy() - Method in class com.hazelcast.client.impl.protocol.ClientMessage.Frame
 
copy(T, boolean) - Method in class com.hazelcast.config.CacheConfig
Copy this CacheConfig to given target object whose type extends CacheConfig.
copy() - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
copy() - Method in class com.hazelcast.config.security.CredentialsIdentityConfig
 
copy() - Method in interface com.hazelcast.config.security.IdentityConfig
Makes a copy (or clone) of the config object.
copy() - Method in class com.hazelcast.config.security.TokenIdentityConfig
 
copy() - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
 
copy(File, File) - Static method in class com.hazelcast.internal.nio.IOUtil
Deep copies source to target and creates the target if necessary.
copy(InputStream, File) - Static method in class com.hazelcast.internal.nio.IOUtil
Deep copies source to target.
copy(IntHashSet) - Method in class com.hazelcast.internal.util.collection.IntHashSet
 
copy(LongHashSet) - Method in class com.hazelcast.internal.util.collection.LongHashSet
copyBehavior - Variable in class com.hazelcast.query.impl.AbstractIndex
 
copyCollections() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
copyFile(File, File, long) - Static method in class com.hazelcast.internal.nio.IOUtil
Copies source file to target and creates the target if necessary.
copyFrom(long) - Method in class com.hazelcast.internal.metrics.managementcenter.ConcurrentArrayRingbuffer
Copies all the items from the given sequence up to the tail.
copyFromByteArray(byte[], int, long, int) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
copyFromByteArray(byte[], int, long, int) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
copyFromByteArray(byte[], int, long, int) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Copies bytes from a Java byte array into this accessor's address space.
copyMemory(Object, long, Object, long, long) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Copies memory from source to destination.
copyMemory(long, long, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
copyMemory(Object, long, Object, long, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
copyMemory(long, long, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
copyMemory(Object, long, Object, long, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
copyMemory(long, long, long) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Copies memory from given source address to given destination address as given size.
CopyOnWriteArrayListStreamSerializer<E> - Class in com.hazelcast.internal.serialization.impl
The CopyOnWriteArrayList serializer
CopyOnWriteArrayListStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.CopyOnWriteArrayListStreamSerializer
 
CopyOnWriteArraySetStreamSerializer<E> - Class in com.hazelcast.internal.serialization.impl
The CopyOnWriteArraySet serializer
CopyOnWriteArraySetStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.CopyOnWriteArraySetStreamSerializer
 
copyTo(byte[], int) - Method in class com.hazelcast.internal.serialization.impl.HeapData
 
copyTo(byte[], int) - Method in interface com.hazelcast.nio.serialization.Data
Copies the payload contained in the Data to the destination buffer.
copyToByteArray(long, byte[], int, int) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
copyToByteArray(long, byte[], int, int) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
copyToByteArray(long, byte[], int, int) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Copies bytes from this accessor's address space to a Java byte array.
copyToHeapBuffer(ByteBuffer, ByteBuffer) - Static method in class com.hazelcast.internal.nio.IOUtil
 
copyWithNewCorrelationId(long) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
Copies the clientMessage efficiently with correlation id Only initialFrame is duplicated, rest of the frames are shared
copyWithoutNulls(T[], T[]) - Static method in class com.hazelcast.internal.util.collection.ArrayUtils
Copy src array into destination and skip null values.
CoreService - Interface in com.hazelcast.internal.services
Marker interface for core Hazelcast services.
CORRELATION_ID_FIELD_OFFSET - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
count() - Static method in class com.hazelcast.aggregation.Aggregators
 
count(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
COUNT - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
count - Variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchTrySetCountCodec.RequestParameters
The number of times countDown must be invoked before threads can pass through await
count(Collection<M>, MemberSelector) - Static method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
 
count(String, String, String) - Method in class com.hazelcast.internal.diagnostics.StoreLatencyPlugin
 
count() - Method in class com.hazelcast.internal.metrics.managementcenter.MetricsCompressor
 
COUNT - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
COUNT_DOWN_LATCH - Static variable in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchDataSerializerHook
 
COUNT_DOWN_LATCH_REGISTRY - Static variable in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchDataSerializerHook
 
COUNT_DOWN_OP - Static variable in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchDataSerializerHook
 
CountAggregator<I> - Class in com.hazelcast.aggregation.impl
 
CountAggregator() - Constructor for class com.hazelcast.aggregation.impl.CountAggregator
 
CountAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.CountAggregator
 
countDown() - Method in class com.hazelcast.client.cp.internal.datastructures.countdownlatch.CountDownLatchProxy
 
countDown() - Method in interface com.hazelcast.cp.ICountDownLatch
Decrements the count of the latch, releasing all waiting threads if the count reaches zero.
countDown(CPGroupId, String, UUID, int) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchService
 
countDown() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.proxy.CountDownLatchProxy
 
countDown() - Method in class com.hazelcast.internal.jmx.CountDownLatchMBean
 
countDownCompletionLatch(int) - Method in class com.hazelcast.cache.impl.AbstractCacheSyncListenerCompleter
 
countDownCompletionLatch(int) - Method in interface com.hazelcast.cache.impl.CacheSyncListenerCompleter
 
CountDownLatch - Class in com.hazelcast.cp.internal.datastructures.countdownlatch
State-machine implementation of the Raft-based count down latch
CountDownLatchAwaitCodec - Class in com.hazelcast.client.impl.protocol.codec
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.
CountDownLatchAwaitCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CountDownLatchAwaitCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CountDownLatchCountDownCodec - Class in com.hazelcast.client.impl.protocol.codec
Decrements the count of the latch, releasing all waiting threads if the count reaches zero.
CountDownLatchCountDownCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CountDownLatchCountDownCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CountDownLatchDataSerializerHook - Class in com.hazelcast.cp.internal.datastructures.countdownlatch
 
CountDownLatchDataSerializerHook() - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchDataSerializerHook
 
CountDownLatchGetCountCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the current count.
CountDownLatchGetCountCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CountDownLatchGetCountCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CountDownLatchGetRoundCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the current round.
CountDownLatchGetRoundCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CountDownLatchGetRoundCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CountDownLatchMBean - Class in com.hazelcast.internal.jmx
Management bean for ICountDownLatch
CountDownLatchMBean(ICountDownLatch, ManagementService) - Constructor for class com.hazelcast.internal.jmx.CountDownLatchMBean
 
CountDownLatchPermission - Class in com.hazelcast.security.permission
 
CountDownLatchPermission(String, String...) - Constructor for class com.hazelcast.security.permission.CountDownLatchPermission
 
CountDownLatchProxy - Class in com.hazelcast.client.cp.internal.datastructures.countdownlatch
Client-side Raft-based proxy implementation of ICountDownLatch
CountDownLatchProxy(ClientContext, RaftGroupId, String, String) - Constructor for class com.hazelcast.client.cp.internal.datastructures.countdownlatch.CountDownLatchProxy
 
CountDownLatchProxy - Class in com.hazelcast.cp.internal.datastructures.countdownlatch.proxy
Server-side Raft-based proxy implementation of ICountDownLatch
CountDownLatchProxy(NodeEngine, RaftGroupId, String, String) - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.proxy.CountDownLatchProxy
 
CountDownLatchRegistry - Class in com.hazelcast.cp.internal.datastructures.countdownlatch
Contains CountDownLatch resources and manages wait timeouts
CountDownLatchService - Class in com.hazelcast.cp.internal.datastructures.countdownlatch
Contains Raft-based count down latch instances
CountDownLatchService(NodeEngine) - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchService
 
CountDownLatchTrySetCountCodec - Class in com.hazelcast.client.impl.protocol.codec
Sets the count to the given value if the current count is zero.
CountDownLatchTrySetCountCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CountDownLatchTrySetCountCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CountDownMessageTask - Class in com.hazelcast.cp.internal.datastructures.countdownlatch.client
Client message task for CountDownOp
CountDownMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.client.CountDownMessageTask
 
CountDownOp - Class in com.hazelcast.cp.internal.datastructures.countdownlatch.operation
CountDownOp() - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.CountDownOp
 
CountDownOp(String, UUID, int) - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.CountDownOp
 
Counter - Interface in com.hazelcast.internal.util.counters
A Counter keeps track of a long value.
CountingMigrationAwareService - Class in com.hazelcast.spi.impl
A MigrationAwareService that delegates to another MigrationAwareService and keeps track of the number of migrations concerning the partition owner (either as current or new replica index) currently in-flight.
CountingMigrationAwareService(FragmentedMigrationAwareService) - Constructor for class com.hazelcast.spi.impl.CountingMigrationAwareService
 
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
 
CP_BASE_DIR_DEFAULT - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
The default directory name for storing CP data.
CP_ENDPOINT - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
CP_GROUP_DESTROYED_EXCEPTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
CP_GROUP_SUMMARY - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
CP_MEMBER - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
CPGroup - Interface in com.hazelcast.cp
Contains information about a CP group.
CPGroup.CPGroupStatus - Enum in com.hazelcast.cp
Represents status of a CP group
CPGroupCreateCPGroupCodec - Class in com.hazelcast.client.impl.protocol.codec
Creates a new CP group with the given name
CPGroupCreateCPGroupCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CPGroupCreateCPGroupCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CPGroupDestroyCPObjectCodec - Class in com.hazelcast.client.impl.protocol.codec
Destroys the distributed object with the given name on the requested CP group
CPGroupDestroyCPObjectCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CPGroupDestroyCPObjectCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CPGroupDestroyedException - Exception in com.hazelcast.cp.exception
A CPSubsystemException which is thrown when a request is sent to a destroyed CP group.
CPGroupDestroyedException() - Constructor for exception com.hazelcast.cp.exception.CPGroupDestroyedException
 
CPGroupDestroyedException(CPGroupId) - Constructor for exception com.hazelcast.cp.exception.CPGroupDestroyedException
 
CPGroupId - Interface in com.hazelcast.cp
Identifier for CP groups.
CPGroupInfo - Class in com.hazelcast.cp.internal
Contains metadata information for Raft groups, such as group id, group members, etc.
CPGroupInfo() - Constructor for class com.hazelcast.cp.internal.CPGroupInfo
 
CPGroupInfo(RaftGroupId, Collection<RaftEndpoint>) - Constructor for class com.hazelcast.cp.internal.CPGroupInfo
 
CPGroupSummary - Class in com.hazelcast.cp.internal
 
CPGroupSummary() - Constructor for class com.hazelcast.cp.internal.CPGroupSummary
 
CPGroupSummary(CPGroupId, CPGroup.CPGroupStatus, Collection<RaftEndpoint>, Collection<CPMember>) - Constructor for class com.hazelcast.cp.internal.CPGroupSummary
 
CPMember - Interface in com.hazelcast.cp
A CP member is a Hazelcast member that is internally elected to be part of the CPSubsystem, hence maintain CP data structures.
CPMemberInfo - Class in com.hazelcast.cp.internal
CPMember represents a member in CP group.
CPMemberInfo() - Constructor for class com.hazelcast.cp.internal.CPMemberInfo
 
CPMemberInfo(UUID, Address) - Constructor for class com.hazelcast.cp.internal.CPMemberInfo
 
CPMemberInfo(Member) - Constructor for class com.hazelcast.cp.internal.CPMemberInfo
 
CPMetadataStore - Interface in com.hazelcast.cp.internal.persistence
Persists and restores CP member metadata of the local member.
CPP - Static variable in class com.hazelcast.client.impl.ClientTypes
CPP client protocol ID
CPPersistenceService - Interface in com.hazelcast.cp.internal.persistence
Defines the contract for providing persistence utilities to CP Subsystem
CPSession - Interface in com.hazelcast.cp.session
Represents a CP session.
CPSession.CPSessionOwnerType - Enum in com.hazelcast.cp.session
Represents type of endpoints that create CP sessions
CPSessionCloseSessionCodec - Class in com.hazelcast.client.impl.protocol.codec
Closes the given session on the given CP group
CPSessionCloseSessionCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CPSessionCloseSessionCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CPSessionCreateSessionCodec - Class in com.hazelcast.client.impl.protocol.codec
Creates a session for the caller on the given CP group.
CPSessionCreateSessionCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CPSessionCreateSessionCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CPSessionGenerateThreadIdCodec - Class in com.hazelcast.client.impl.protocol.codec
Generates a new ID for the caller thread.
CPSessionGenerateThreadIdCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CPSessionGenerateThreadIdCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CPSessionHeartbeatSessionCodec - Class in com.hazelcast.client.impl.protocol.codec
Commits a heartbeat for the given session on the given cP group and extends its session expiration time.
CPSessionHeartbeatSessionCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CPSessionHeartbeatSessionCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
CPSessionInfo - Class in com.hazelcast.cp.internal.session
Represents state of a CP session.
CPSessionInfo() - Constructor for class com.hazelcast.cp.internal.session.CPSessionInfo
 
CPSessionManagementService - Interface in com.hazelcast.cp.session
This interface offers API for managing CP sessions.
CPSubsystem - Interface in com.hazelcast.cp
CP Subsystem is a component of Hazelcast that builds a strongly consistent layer for a set of distributed data structures.
CPSubsystemConfig - Class in com.hazelcast.config.cp
Contains configuration options for CP Subsystem.
CPSubsystemConfig() - Constructor for class com.hazelcast.config.cp.CPSubsystemConfig
 
CPSubsystemConfig(CPSubsystemConfig) - Constructor for class com.hazelcast.config.cp.CPSubsystemConfig
 
CPSubsystemException - Exception in com.hazelcast.cp.exception
Base exception for failures in CP Subsystem
CPSubsystemException(UUID) - Constructor for exception com.hazelcast.cp.exception.CPSubsystemException
 
CPSubsystemException(String, UUID) - Constructor for exception com.hazelcast.cp.exception.CPSubsystemException
 
CPSubsystemException(String, Throwable, UUID) - Constructor for exception com.hazelcast.cp.exception.CPSubsystemException
 
CPSubsystemImpl - Class in com.hazelcast.client.cp.internal
Client-side impl of the CP subsystem to create CP data structure proxies
CPSubsystemImpl(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.cp.internal.CPSubsystemImpl
 
CPSubsystemImpl - Class in com.hazelcast.cp.internal
Provides access to CP Subsystem utilities
CPSubsystemImpl(HazelcastInstanceImpl) - Constructor for class com.hazelcast.cp.internal.CPSubsystemImpl
 
CPSubsystemManagementService - Interface in com.hazelcast.cp
This interface offers APIs for managing CP members and groups.
CRDT<T extends CRDT<T>> - Interface in com.hazelcast.internal.crdt
Common interface for CRDT (conflict-free replicated data type) implementations.
CRDT_REPLICATION_MIGRATION_EXECUTOR - Static variable in class com.hazelcast.internal.crdt.CRDTReplicationMigrationService
The executor for the CRDT replication and migration tasks
CRDT_TIMESTAMPED_LONG - Static variable in class com.hazelcast.internal.crdt.CRDTDataSerializerHook
The constant for the PNCounter CRDTTimestampedLong
CRDTDataSerializerHook - Class in com.hazelcast.internal.crdt
Serialization constants for all CRDT related objects
CRDTDataSerializerHook() - Constructor for class com.hazelcast.internal.crdt.CRDTDataSerializerHook
 
CRDTReplicationAwareService<T> - Interface in com.hazelcast.internal.crdt
Represents a service implementing a CRDT that may be replicated and migrated to other replicas of the same CRDT.
CRDTReplicationConfig - Class in com.hazelcast.config
Configures the replication mechanism for all CRDT implementations.
CRDTReplicationConfig() - Constructor for class com.hazelcast.config.CRDTReplicationConfig
 
CRDTReplicationContainer - Class in com.hazelcast.internal.crdt
A container for a CRDT replication operation.
CRDTReplicationContainer(Operation, Map<String, VectorClock>) - Constructor for class com.hazelcast.internal.crdt.CRDTReplicationContainer
 
CRDTReplicationMigrationService - Class in com.hazelcast.internal.crdt
Service that handles replication and migration of CRDT data for all CRDT implementations.
CRDTReplicationMigrationService() - Constructor for class com.hazelcast.internal.crdt.CRDTReplicationMigrationService
 
CRDTTimestampedLong - Class in com.hazelcast.internal.crdt.pncounter.operations
Response for CRDT PN counter operations which contains the PN counter value as well as the current replica vector clock.
CRDTTimestampedLong() - Constructor for class com.hazelcast.internal.crdt.pncounter.operations.CRDTTimestampedLong
 
CRDTTimestampedLong(long, VectorClock) - Constructor for class com.hazelcast.internal.crdt.pncounter.operations.CRDTTimestampedLong
 
create(String, ClientContext) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxyFactory
 
create(ClientMessage, Connection) - Method in class com.hazelcast.client.impl.CompositeMessageTaskFactory
 
create(ClientMessage, Connection) - Method in interface com.hazelcast.client.impl.protocol.MessageTaskFactory
 
create(String, ClientContext) - Method in interface com.hazelcast.client.impl.spi.ClientProxyFactory
Creates a new client proxy with the given ID
create(String, QueueStoreConfig, SerializationService, ClassLoader) - Static method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
Factory method that creates a QueueStoreWrapper
create(Node, List<String>) - Static method in class com.hazelcast.instance.impl.NodeExtensionFactory
Uses the Hazelcast ServiceLoader to discover all registered NodeExtension classes and identify the one to instantiate and use as the provided node's extension.
create(int) - Method in class com.hazelcast.internal.serialization.impl.ArrayDataSerializableFactory
 
create(int, Version, Version) - Method in class com.hazelcast.internal.serialization.impl.ArrayDataSerializableFactory
 
create(InternalSerializationService) - Method in interface com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolFactory
 
create(InternalSerializationService) - Method in class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolFactoryImpl
 
create(Throwable, String) - Method in interface com.hazelcast.internal.util.ExceptionUtil.RuntimeExceptionFactory
 
create(QueryCacheRequest, String) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheFactory
 
create(int) - Method in interface com.hazelcast.nio.serialization.DataSerializableFactory
Creates an IdentifiedDataSerializable instance using given type ID
create(int, Version, Version) - Method in interface com.hazelcast.nio.serialization.impl.VersionedDataSerializableFactory
Creates an IdentifiedDataSerializable instance using given type ID and object version
create(int) - Method in interface com.hazelcast.nio.serialization.PortableFactory
Creates a Portable instance using given class ID
create(ObjectNamespace, RingbufferStoreConfig, InMemoryFormat, SerializationService, ClassLoader) - Static method in class com.hazelcast.ringbuffer.impl.RingbufferStoreWrapper
Factory method that creates a RingbufferStoreWrapper.
CREATE - Static variable in class com.hazelcast.security.permission.InstancePermission
 
create(int) - Method in interface com.hazelcast.spi.impl.operationservice.PartitionTaskFactory
Creates the task.
CREATE_ACCUMULATOR_INFO - Static variable in class com.hazelcast.map.impl.client.MapPortableHook
 
CREATE_ALLOWED_DURING_PASSIVE_STATE_TX_BACKUP_LOG - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
CREATE_CONFIG - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CREATE_RAFT_GROUP_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
CREATE_RAFT_NODE_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
CREATE_SESSION_OP - Static variable in class com.hazelcast.cp.internal.session.RaftSessionServiceDataSerializerHook
 
CREATE_TX_BACKUP_LOG - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
createAccumulator(AccumulatorInfo) - Method in interface com.hazelcast.map.impl.querycache.accumulator.AccumulatorFactory
 
createAccumulator(AccumulatorInfo) - Method in class com.hazelcast.map.impl.querycache.publisher.PublisherAccumulatorFactory
 
createAccumulator(AccumulatorInfo) - Method in class com.hazelcast.map.impl.querycache.subscriber.SubscriberAccumulatorFactory
 
createAccumulatorHandler(QueryCacheContext, AccumulatorInfo) - Method in class com.hazelcast.map.impl.querycache.accumulator.BasicAccumulator
 
createAccumulatorHandler(QueryCacheContext, AccumulatorInfo) - Method in class com.hazelcast.map.impl.querycache.subscriber.SubscriberAccumulator
 
createAccumulatorProcessor(AccumulatorInfo, QueryCacheEventService) - Method in class com.hazelcast.map.impl.querycache.accumulator.BasicAccumulator
 
createAddress(String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.CustomTypeFactory
 
createAddressPicker(Node) - Method in class com.hazelcast.instance.impl.DefaultNodeContext
 
createAddressPicker(Node) - Method in interface com.hazelcast.instance.impl.NodeContext
 
createAdHocRunner() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationRunnerFactory
Creates an ad hoc generic OperationRunner.
createAllLocalMapStats() - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
 
createAllowedDuringPassiveStateBackupLog(UUID, UUID) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
CreateAllowedDuringPassiveStateTxBackupLogOperation - Class in com.hazelcast.transaction.impl.operations
 
CreateAllowedDuringPassiveStateTxBackupLogOperation() - Constructor for class com.hazelcast.transaction.impl.operations.CreateAllowedDuringPassiveStateTxBackupLogOperation
 
CreateAllowedDuringPassiveStateTxBackupLogOperation(UUID, UUID) - Constructor for class com.hazelcast.transaction.impl.operations.CreateAllowedDuringPassiveStateTxBackupLogOperation
 
createAlsoOnOthers - Variable in class com.hazelcast.client.impl.protocol.codec.CacheCreateConfigCodec.RequestParameters
True if the configuration shall be created on all members, false otherwise.
createAmbigiousConfigrationException(String, String, String) - Static method in class com.hazelcast.internal.config.ConfigUtils
 
createAndFillBeanBuilder(Node, Class, String, BeanDefinitionBuilder, String...) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
createAndFillListedBean(Node, Class, String, ManagedMap<String, AbstractBeanDefinition>, String...) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
createAndSetPhoneHome() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
createBackoffIdleStrategy(String) - Static method in class com.hazelcast.internal.util.concurrent.BackoffIdleStrategy
Creates a new BackoffIdleStrategy.
createBackupEntryProcessor() - Method in interface com.hazelcast.cache.BackupAwareEntryProcessor
Either creates a new, specialized EntryProcessor to be executed on the backup-partition, or returns
createBackupLog(UUID, UUID) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
createBaseEventContext(CacheEventType, Data, Data, long, UUID, int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
 
createBeanBuilder(Class) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
createBoundedWriteBehindQueue(MapStoreContext) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueues
 
createCache(String, C) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
createCacheCompleteEvent(int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
 
createCacheCompleteEvent(Data, int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
 
createCacheCompleteEvent(Data, long, UUID, int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
 
createCacheConfig(String, C) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
createCacheConfig(String, CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
createCacheConfig(String, CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
 
createCacheConfig(String, CacheConfig<K, V>) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
 
createCacheConfigOnAllMembers(PreJoinCacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
createCacheConfigOnAllMembers(PreJoinCacheConfig<K, V>) - Method in interface com.hazelcast.cache.impl.ICacheService
Creates the given CacheConfig on all members of the cluster synchronously.
createCacheConfigOnAllMembersAsync(PreJoinCacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
createCacheCreatedEvent(Data, Data, long, UUID, 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
 
createCacheEventData(String, int, Data, Data, Data, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.CustomTypeFactory
 
createCacheEvictionChecker(int, EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
Creates an instance for checking if the maximum cache size has been reached.
createCacheEvictionChecker(int, EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.cache.impl.CacheRecordStore
Creates an instance for checking if the maximum cache size has been reached.
createCacheExpiredEvent(Data, Data, long, UUID, int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
 
createCacheManager(HazelcastInstance, URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
 
createCacheManager(HazelcastInstance, URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.impl.HazelcastServerCachingProvider
 
createCacheManager(HazelcastInstance, URI, ClassLoader, Properties) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCachingProvider
 
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
 
createCacheRemovedEvent(Data, Data, long, UUID, int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
 
createCacheRemovedEvent(Data) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
 
createCacheSimpleEntryListenerConfig(boolean, boolean, String, String) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.CustomTypeFactory
 
createCacheStatIfAbsent(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
createCacheStatIfAbsent(String) - Method in interface com.hazelcast.cache.impl.ICacheService
 
createCacheUpdatedEvent(Data, Data, Data, long, long, long, long, UUID, int, Data) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
 
createCacheUpdatedEvent(Data, Data, Data, long, long, long, long, Data) - 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.
createChannelInitializer() - Method in interface com.hazelcast.client.impl.ClientExtension
 
createChannelInitializer(SSLConfig, SocketOptions) - Method in interface com.hazelcast.client.impl.ClientExtension
 
createChannelInitializer() - Method in class com.hazelcast.client.impl.clientside.DefaultClientExtension
 
createChannelInitializer(SSLConfig, SocketOptions) - Method in class com.hazelcast.client.impl.clientside.DefaultClientExtension
 
createChannelInitializerProvider(IOService) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
createChannelInitializerProvider(IOService) - Method in interface com.hazelcast.instance.impl.NodeExtension
Creates the ChannelInitializerProvider.
createClearOperation(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createClearOperation(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createClearOperationFactory() - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
 
createClearOperationFactory() - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
 
createClearOperationFactory(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createClearOperationFactory(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createClientLoginContext(Credentials, Connection) - Method in interface com.hazelcast.security.SecurityContext
Creates client LoginContext.
createClientProxyDescriptors() - Method in interface com.hazelcast.client.impl.spi.ClientProxyDescriptorProvider
Return registered clientProxy descriptors
createCollection(MultiMapConfig.ValueCollectionType) - Static method in class com.hazelcast.multimap.impl.ValueCollectionFactory
Picks right collection type, like Set or List depending on the MultiMapConfig.getValueCollectionType() and creates it.
createCollection(Collection) - Static method in class com.hazelcast.multimap.impl.ValueCollectionFactory
Creates a same type collection with the given collection depending on the MultiMapConfig.getValueCollectionType().
createCollection(MultiMapConfig.ValueCollectionType, int) - Static method in class com.hazelcast.multimap.impl.ValueCollectionFactory
Picks right collection type, like Set or List depending on the MultiMapConfig.getValueCollectionType() and creates it.
createConcurrentHashMap(int) - Static method in class com.hazelcast.internal.util.MapUtil
Utility method that creates an LinkedHashMap with its initialCapacity calculated to minimize rehash operations
createConcurrentSet() - Method in class com.hazelcast.config.AbstractCacheConfig
 
createConfigCheck() - Method in class com.hazelcast.instance.impl.Node
 
createConnectionManager(HazelcastClientInstanceImpl) - Method in interface com.hazelcast.client.impl.clientside.ClientConnectionManagerFactory
 
createConnectionManager(HazelcastClientInstanceImpl) - Method in class com.hazelcast.client.impl.clientside.DefaultClientConnectionManagerFactory
 
createContainsKeyOperation(Data) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
 
createContainsKeyOperation(Data) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
 
createContainsKeyOperation(String, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createContainsKeyOperation(String, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createContainsValueOperationFactory(String, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createContainsValueOperationFactory(String, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createCopy(T[]) - Static method in class com.hazelcast.internal.util.collection.ArrayUtils
Create copy of the src array.
createCreateTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.AllowedDuringPassiveStateTransactionImpl
 
createCreateTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
createCursor(String) - Static method in class com.hazelcast.query.impl.getters.JsonPathCursor
Creates a new cursor from given attribute path.
createDefaultEntryView(Data, Data, Data, CacheRecord<Object, Data>) - Static method in class com.hazelcast.cache.impl.CacheEntryViews
Creates a DefaultCacheEntryView instance.
createDefaultWriteBehindQueue() - Static method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueues
 
createDeleteOperation(String, Data, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createDeleteOperation(String, Data, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
Creates a delete operation for an entry with key equal to key from the map named name.
createDestroyQueryCacheOperation(String, String) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientSubscriberContextSupport
 
createDestroyQueryCacheOperation(String, String) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeSubscriberContextSupport
 
createDestroyQueryCacheOperation(String, String) - Method in interface com.hazelcast.map.impl.querycache.subscriber.SubscriberContextSupport
Creates recovery operation for event loss cases.
createDisabled() - Static method in class com.hazelcast.internal.util.ConcurrencyDetection
 
createDiscoveryService(DiscoveryConfig, List<DiscoveryStrategyConfig>, Member) - Method in class com.hazelcast.instance.impl.Node
 
createDiscoveryStrategyConfigs(ClientConfig) - Static method in class com.hazelcast.client.config.ClientAliasedDiscoveryConfigUtils
Extracts aliased discovery configs from config and creates a list of DiscoveryStrategyConfig out of them.
createDiscoveryStrategyConfigs(JoinConfig) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Extracts aliased discovery configs from config and creates a list of DiscoveryStrategyConfig out of them.
createDiscoveryStrategyConfigs(WanBatchReplicationPublisherConfig) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Extracts aliased discovery configs from config and creates a list of DiscoveryStrategyConfig out of them.
createDistributedObject(String, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
createDistributedObject(String, boolean) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorService
 
createDistributedObject(String, boolean) - Method in class com.hazelcast.collection.impl.list.ListService
 
createDistributedObject(String, boolean) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
createDistributedObject(String, boolean) - Method in class com.hazelcast.collection.impl.set.SetService
 
createDistributedObject(String, boolean) - Method in class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
 
createDistributedObject(String, boolean) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
 
createDistributedObject(String, boolean) - Method in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorService
 
createDistributedObject(String, boolean) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterService
 
createDistributedObject(String, boolean) - Method in class com.hazelcast.internal.longregister.LongRegisterService
 
createDistributedObject(String, boolean) - Method in interface com.hazelcast.internal.services.RemoteService
Creates a distributed object on the local member only (when local is true), else cluster-wide.
createDistributedObject(String) - Method in interface com.hazelcast.internal.services.RemoteService
Creates a distributed object on the cluster.
createDistributedObject(String, boolean) - Method in class com.hazelcast.map.impl.MapService
 
createDistributedObject(String, boolean) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
createDistributedObject(String, boolean) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
createDistributedObject(String, boolean) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
createDistributedObject(String, boolean) - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
createDistributedObject(String, boolean) - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicService
 
createDistributedObject(String, boolean) - Method in class com.hazelcast.topic.impl.TopicService
 
createDistributedObject(String, boolean) - Method in class com.hazelcast.transaction.impl.xa.XAService
 
createDistributedObjectsOnCluster(Connection) - Method in class com.hazelcast.client.impl.spi.ProxyManager
 
createDurationConfig(long, int) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.CustomTypeFactory
 
createDynamicConfigListener() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
createDynamicConfigListener() - Method in interface com.hazelcast.instance.impl.NodeExtension
Creates a listener for changes in dynamic data structure configurations
createEmptyResponseHandler() - Static method in class com.hazelcast.spi.impl.operationservice.OperationResponseHandlerFactory
 
createEnabled(long) - Static method in class com.hazelcast.internal.util.ConcurrencyDetection
 
createEntryCountResolver(CacheContext) - Static method in class com.hazelcast.cache.impl.CacheEntryCountResolver
 
createEntryIteratorOperation(int, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
 
createEntryIteratorOperation(int, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
 
createEntryOperation(String, Data, EntryProcessor) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createEntryOperation(String, Data, EntryProcessor) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createEntryProcessorOperation(Data, Integer, EntryProcessor, Object...) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
 
createEntryProcessorOperation(Data, Integer, EntryProcessor, Object...) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
 
createEntryView(Data, Data, CacheRecord) - Static method in class com.hazelcast.cache.impl.CacheEntryViews
 
createEntryView(Data, Data, Data, CacheRecord, CacheEntryViews.CacheEntryViewType) - Static method in class com.hazelcast.cache.impl.CacheEntryViews
Creates a CacheEntryView instance.
createErrorLoggingResponseHandler(ILogger) - Static method in class com.hazelcast.spi.impl.operationservice.OperationResponseHandlerFactory
 
createEventJournalConfig(boolean, int, int) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.CustomTypeFactory
 
createEvictAllOperation(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createEvictAllOperation(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createEvictAllOperationFactory(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createEvictAllOperationFactory(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createEvictionPolicyEvaluator(EvictionConfig) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
createEvictionStrategy(EvictionConfig) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
createEvictOperation(String, Data, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createEvictOperation(String, Data, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createException(ClientMessage) - Method in class com.hazelcast.client.impl.clientside.ClientExceptionFactory
 
createException(String, Throwable) - Method in interface com.hazelcast.client.impl.clientside.ClientExceptionFactory.ExceptionFactory
 
createExceptionMessage(Throwable) - Method in class com.hazelcast.client.impl.protocol.ClientExceptions
 
createExecutorContainer(String, TaskRingBuffer) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorPartitionContainer
 
createExtensionServices() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
createExtensionServices() - Method in interface com.hazelcast.instance.impl.NodeExtension
Creates additional extension services, which will be registered by service manager during start-up.
createFactory() - Method in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
createFactory() - Method in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
createFactory() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorDataSerializerHook
 
createFactory() - Method in class com.hazelcast.client.impl.ClientDataSerializerHook
 
createFactory() - Method in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
createFactory() - Method in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
createFactory() - Method in class com.hazelcast.config.ConfigDataSerializerHook
 
createFactory() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongDataSerializerHook
 
createFactory() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefDataSerializerHook
 
createFactory() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchDataSerializerHook
 
createFactory() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockDataSerializerHook
 
createFactory() - Method in class com.hazelcast.cp.internal.datastructures.RaftDataServiceDataSerializerHook
 
createFactory() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreDataSerializerHook
 
createFactory() - Method in class com.hazelcast.cp.internal.raft.impl.RaftDataSerializerHook
 
createFactory() - Method in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
createFactory() - Method in class com.hazelcast.cp.internal.session.RaftSessionServiceDataSerializerHook
 
createFactory() - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorDataSerializerHook
 
createFactory() - Method in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
 
createFactory() - Method in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorDataSerializerHook
 
createFactory() - Method in class com.hazelcast.internal.ascii.TextProtocolsDataSerializerHook
 
createFactory() - Method in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
createFactory() - Method in class com.hazelcast.internal.crdt.CRDTDataSerializerHook
 
createFactory() - Method in class com.hazelcast.internal.journal.EventJournalDataSerializerHook
 
createFactory() - Method in class com.hazelcast.internal.locksupport.LockDataSerializerHook
 
createFactory() - Method in class com.hazelcast.internal.longregister.LongRegisterDataSerializerHook
 
createFactory() - Method in class com.hazelcast.internal.management.ManagementDataSerializerHook
 
createFactory() - Method in class com.hazelcast.internal.metrics.managementcenter.MetricsDataSerializerHook
 
createFactory() - Method in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
createFactory() - Method in class com.hazelcast.internal.partition.impl.PartitionPortableHook
 
createFactory() - Method in interface com.hazelcast.internal.serialization.DataSerializerHook
 
createFactory() - Method in interface com.hazelcast.internal.serialization.PortableHook
 
createFactory() - Method in class com.hazelcast.internal.usercodedeployment.impl.UserCodeDeploymentSerializerHook
 
createFactory() - Method in class com.hazelcast.map.impl.client.MapPortableHook
 
createFactory() - Method in class com.hazelcast.map.impl.MapDataSerializerHook
 
createFactory() - Method in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
createFactory() - Method in class com.hazelcast.projection.impl.ProjectionDataSerializerHook
 
createFactory() - Method in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
createFactory() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
 
createFactory() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
createFactory() - Method in class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
 
createFactory() - Method in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
 
createFactory() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
createFactory() - Method in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
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.transaction.impl.TransactionDataSerializerHook
 
createFactory() - Method in class com.hazelcast.wan.impl.WanDataSerializerHook
 
createFactoryOnRunner(NodeEngine, int[]) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperationFactory
 
createFactoryOnRunner(NodeEngine, int[]) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionAwareOperationFactory
This method will be called on operation runner node.
createFetchEntriesOperation(String, int, int) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createFetchEntriesOperation(String, int, int) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createFetchKeysOperation(String, int, int) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createFetchKeysOperation(String, int, int) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createFetchWithQueryOperation(String, int, int, Query) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createFetchWithQueryOperation(String, int, int, Query) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
Creates an operation for fetching a segment of a query result from a single partition.
createForDecode(ClientMessage.Frame) - Static method in class com.hazelcast.client.impl.protocol.ClientMessage
 
createForEncode() - Static method in class com.hazelcast.client.impl.protocol.ClientMessage
 
createFromData(Data) - Method in class com.hazelcast.map.impl.JsonMetadataInitializer
 
createFromData(Data) - Method in interface com.hazelcast.map.impl.MetadataInitializer
Returns metadata for given binary data.
createFromObject(Object) - Method in class com.hazelcast.map.impl.JsonMetadataInitializer
 
createFromObject(Object) - Method in interface com.hazelcast.map.impl.MetadataInitializer
Returns metadata for given object.
createGenericRunner() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationRunnerFactory
Creates an OperationRunner to execute generic Operations.
createGetAllOperationFactory(Set<Data>, ExpiryPolicy) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
 
createGetAllOperationFactory(Set<Data>, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
 
createGetAllOperationFactory(String, List<Data>) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createGetAllOperationFactory(String, List<Data>) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createGetAndRemoveOperation(Data, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
 
createGetAndRemoveOperation(Data, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
 
createGetAndReplaceOperation(Data, Data, ExpiryPolicy, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
 
createGetAndReplaceOperation(Data, Data, ExpiryPolicy, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
 
createGetEntryViewOperation(String, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createGetEntryViewOperation(String, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createGetOperation(Data, ExpiryPolicy) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
 
createGetOperation(Data, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
 
createGetOperation(String, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createGetOperation(String, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createGetter(Object, String) - Static method in class com.hazelcast.query.impl.getters.ReflectionHelper
 
createHashMap(int) - Static method in class com.hazelcast.internal.util.MapUtil
Utility method that creates an HashMap with its initialCapacity calculated to minimize rehash operations
createHashSet(int) - Static method in class com.hazelcast.internal.util.SetUtil
Utility method that creates an HashSet with its initialCapacity calculated to minimize rehash operations
createHotRestartConfig(boolean, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.CustomTypeFactory
 
createIMapEvent(EventData, EventFilter, Member, SerializationService) - Static method in class com.hazelcast.map.impl.querycache.subscriber.EventPublisherHelper
 
createInboundHandlers(EndpointQualifier, TcpIpConnection, IOService) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
createInboundHandlers(EndpointQualifier, TcpIpConnection, IOService) - Method in interface com.hazelcast.instance.impl.NodeExtension
Creates a InboundHandler for given Connection instance.
createInboundHandlers(EndpointQualifier, TcpIpConnection) - Method in interface com.hazelcast.internal.nio.IOService
 
createInboundHandlers(EndpointQualifier, TcpIpConnection) - Method in class com.hazelcast.internal.nio.NodeIOService
 
createIndex(IndexConfig, Extractors, InternalSerializationService, IndexCopyBehavior, PerIndexStats, StoreAdapter) - Method in class com.hazelcast.query.impl.DefaultIndexProvider
 
createIndex(IndexConfig, Extractors, InternalSerializationService, IndexCopyBehavior, PerIndexStats, StoreAdapter) - Method in interface com.hazelcast.query.impl.IndexProvider
Creates a new index with the given name.
createIndexConfig(String, int, List<String>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.CustomTypeFactory
 
createIndexConfig(IndexType, String...) - Static method in class com.hazelcast.query.impl.IndexUtils
Create simple index definition with the given attributes
createIndexes(boolean) - Method in class com.hazelcast.map.impl.MapContainer
 
createIndexesFromRecordedDefinitions(StoreAdapter) - Method in class com.hazelcast.query.impl.Indexes
Creates indexes according to the index definitions stored inside this indexes.
createIndexStore(boolean, PerIndexStats) - Method in class com.hazelcast.query.impl.AbstractIndex
 
createIndexStore(boolean, PerIndexStats) - Method in class com.hazelcast.query.impl.IndexImpl
 
createInput(Data, InternalSerializationService) - Method in interface com.hazelcast.internal.serialization.InputOutputFactory
 
createInput(byte[], InternalSerializationService) - Method in interface com.hazelcast.internal.serialization.InputOutputFactory
 
createInputOutputFactory() - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
createInstanceMBean(HazelcastInstanceImpl) - Method in class com.hazelcast.internal.jmx.ManagementService
 
createInstanceName(Config) - Static method in class com.hazelcast.instance.impl.HazelcastInstanceFactory
 
createInt2ObjectHashMap(int) - Static method in class com.hazelcast.internal.util.MapUtil
Utility method that creates an Int2ObjectHashMap with its initialCapacity calculated to minimize rehash operations
createInternalMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.ConfigMemberGroupFactory
 
createInternalMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.HostAwareMemberGroupFactory
 
createInternalMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.SPIAwareMemberGroupFactory
 
createInternalMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.ZoneAwareMemberGroupFactory
 
createInvocationBuilder(Operation) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
createInvocationBuilder(Operation) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorMemberOwnedContainer
 
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.impl.operationservice.OperationService
 
createInvocationBuilder(String, Operation, Address) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
 
createItemIdArray() - Method in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
Creates an array of IDs for all operations in this transaction log.
createJMXManagementService(HazelcastInstanceImpl) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
createJMXManagementService(HazelcastInstanceImpl) - Method in interface com.hazelcast.instance.impl.NodeExtension
 
createJoiner(Node) - Method in class com.hazelcast.instance.impl.DefaultNodeContext
 
createJoiner(Node) - Method in interface com.hazelcast.instance.impl.NodeContext
 
createJoinRequest(boolean) - Method in class com.hazelcast.instance.impl.Node
 
createKeyIteratorOperation(int, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
 
createKeyIteratorOperation(int, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
 
createLazyEntryView(Data, Data, Data, CacheRecord) - Static method in class com.hazelcast.cache.impl.CacheEntryViews
Creates a LazyCacheEntryView instance.
createLinkedHashMap(int) - Static method in class com.hazelcast.internal.util.MapUtil
Utility method that creates an LinkedHashMap with its initialCapacity calculated to minimize rehash operations
createLinkedHashSet(int) - Static method in class com.hazelcast.internal.util.SetUtil
Utility method that creates an LinkedHashSet with its initialCapacity calculated to minimize rehash operations
createListenerAdapter(Object) - Static method in class com.hazelcast.map.impl.ListenerAdapters
 
createListenerAdapters(EntryListener) - Static method in class com.hazelcast.map.impl.EntryListenerAdaptors
Creates a ListenerAdapter array for all event types of EntryEventType.
createListenerAdapters(MapListener) - Static method in class com.hazelcast.map.impl.MapListenerAdaptors
Creates a ListenerAdapter array for all event types of EntryEventType.
createLoadAllOperation(String, List<Data>, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createLoadAllOperation(String, List<Data>, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
Creates an operation to load entry values for the provided keys on the partition owner.
createLoadAllOperationFactory(Set<Data>, boolean) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
 
createLoadAllOperationFactory(Set<Data>, boolean) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
 
createLoadAllOperationFactory(String, List<Data>, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createLoadAllOperationFactory(String, List<Data>, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createLoadMapOperation(String, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createLoadMapOperation(String, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createLocalMapStats(String) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
 
createLocalQueueStats(String, int) - Method in class com.hazelcast.collection.impl.queue.QueueService
Returns the local queue statistics for the given name and partition ID.
createLocalQueueStats(String) - Method in class com.hazelcast.collection.impl.queue.QueueService
Returns the local queue statistics for the queue with the given name.
createLockStore(int, ObjectNamespace) - Method in interface com.hazelcast.internal.locksupport.LockSupportService
 
createLockStore(int, ObjectNamespace) - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
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
 
createMapFlushOperation(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createMapFlushOperation(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createMapFlushOperationFactory(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createMapFlushOperationFactory(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createMapService() - Method in interface com.hazelcast.map.impl.MapServiceFactory
Returns a MapService object.
createMapSizeEstimator(InMemoryFormat) - Static method in class com.hazelcast.map.impl.OwnedEntryCostEstimatorFactory
 
createMapSizeOperationFactory(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createMapSizeOperationFactory(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createMapStoreContext(MapContainer) - Static method in class com.hazelcast.map.impl.mapstore.MapStoreContextFactory
 
createMemberGroups(Collection<? extends Member>) - Method in interface com.hazelcast.partition.membergroup.MemberGroupFactory
 
createMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroupFactory
 
createMemberLoginContext(Credentials, Connection) - Method in interface com.hazelcast.security.SecurityContext
Creates member LoginContext.
createMemberUuid() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
createMemberUuid() - Method in interface com.hazelcast.instance.impl.NodeExtension
Creates a UUID for local member
createMergeOperation(String, List<SplitBrainMergeTypes.CacheMergeTypes>, SplitBrainMergePolicy<Data, SplitBrainMergeTypes.CacheMergeTypes>) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
 
createMergeOperation(String, List<SplitBrainMergeTypes.CacheMergeTypes>, SplitBrainMergePolicy<Data, SplitBrainMergeTypes.CacheMergeTypes>) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
 
createMergeOperation(String, SplitBrainMergeTypes.MapMergeTypes, SplitBrainMergePolicy<Data, SplitBrainMergeTypes.MapMergeTypes>, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createMergeOperation(String, SplitBrainMergeTypes.MapMergeTypes, SplitBrainMergePolicy<Data, SplitBrainMergeTypes.MapMergeTypes>, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createMergeOperationFactory(String, int[], List<SplitBrainMergeTypes.CacheMergeTypes>[], SplitBrainMergePolicy<Data, SplitBrainMergeTypes.CacheMergeTypes>) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
 
createMergeOperationFactory(String, int[], List<SplitBrainMergeTypes.CacheMergeTypes>[], SplitBrainMergePolicy<Data, SplitBrainMergeTypes.CacheMergeTypes>) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
 
createMergeOperationFactory(String, int[], List<SplitBrainMergeTypes.MapMergeTypes>[], SplitBrainMergePolicy<Data, SplitBrainMergeTypes.MapMergeTypes>) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createMergeOperationFactory(String, int[], List<SplitBrainMergeTypes.MapMergeTypes>[], SplitBrainMergePolicy<Data, SplitBrainMergeTypes.MapMergeTypes>) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createMergeOperationFactory(String, SplitBrainMergePolicy<V, MergingItem>, int[], List<MergingItem>[]) - Method in class com.hazelcast.spi.impl.merge.AbstractMergeRunnable
Returns an OperationFactory for SplitBrainMergePolicy, legacy merge policies don't use this method.
createMergingEntry(SerializationService, EntryView<Data, Data>) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
 
createMergingEntry(SerializationService, Record) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
 
createMergingEntry(SerializationService, Data, Data, Record) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
 
createMergingEntry(SerializationService, CacheEntryView<Data, Data>) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
 
createMergingEntry(SerializationService, Data, Data, R) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
 
createMergingEntry(SerializationService, ReplicatedRecord) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
 
createMergingEntry(SerializationService, MultiMapMergeContainer) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
 
createMergingEntry(SerializationService, MultiMapContainer, Data, Collection<MultiMapRecord>, long) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
 
createMergingEntry(SerializationService, String, HyperLogLog) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
 
createMergingEntry(SerializationService, ScheduledTaskDescriptor) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
 
createMergingValue(SerializationService, Collection<CollectionItem>) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
 
createMergingValue(SerializationService, Queue<QueueItem>) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
 
createMergingValue(SerializationService, Long) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
 
createMergingValue(SerializationService, Data) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
 
createMergingValue(SerializationService, Ringbuffer<Object>) - Static method in class com.hazelcast.spi.impl.merge.MergingValueFactory
 
createMerkleTreeConfig(boolean, int) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.CustomTypeFactory
 
createMulticastInputProcessor(IOService) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
createMulticastInputProcessor(IOService) - Method in interface com.hazelcast.instance.impl.NodeExtension
Returns a byte array processor for incoming data on the Multicast joiner
createMulticastOutputProcessor(IOService) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
createMulticastOutputProcessor(IOService) - Method in interface com.hazelcast.instance.impl.NodeExtension
Returns a byte array processor for outgoing data on the Multicast joiner
createMulticastService(Address, Node, Config, ILogger) - Static method in class com.hazelcast.internal.cluster.impl.MulticastService
 
createMultipleEntryOperationFactory(String, Set<Data>, EntryProcessor) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createMultipleEntryOperationFactory(String, Set<Data>, EntryProcessor) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createNearCache(String, NearCacheConfig) - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
 
createNearCacheEvictionChecker(EvictionConfig, NearCacheConfig) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
createNearCacheEvictionChecker(EvictionConfig, NearCacheConfig) - Method in class com.hazelcast.internal.nearcache.impl.store.BaseHeapNearCacheRecordStore
 
createNearCacheManager() - Method in interface com.hazelcast.client.impl.ClientExtension
Creates a NearCacheManager instance to be used by this client.
createNearCacheManager() - Method in class com.hazelcast.client.impl.clientside.DefaultClientExtension
 
createNearCachePreloaderConfig(boolean, String, int, int) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.CustomTypeFactory
 
createNearCacheRecordMap(NearCacheConfig) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
createNearCacheRecordMap(NearCacheConfig) - Method in class com.hazelcast.internal.nearcache.impl.store.BaseHeapNearCacheRecordStore
 
createNearCacheRecordStore(String, NearCacheConfig) - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
createNetworkingService(Node, ServerSocketRegistry) - Method in class com.hazelcast.instance.impl.DefaultNodeContext
 
createNetworkingService(Node, ServerSocketRegistry) - Method in interface com.hazelcast.instance.impl.NodeContext
 
createNew(String) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
 
createNew(int, Collection<MemberImpl>) - Static method in class com.hazelcast.internal.cluster.impl.MembersView
Creates a new MemberMap including given members.
createNew(K) - Method in interface com.hazelcast.internal.util.ConstructorFunction
Creates a new instance of an object given the construction argument
createNew(K, Version, Version) - Method in interface com.hazelcast.internal.util.VersionAwareConstructorFunction
Creates a new instance of an object given the construction argument and the version of the object.
createNew(String) - Method in class com.hazelcast.map.impl.querycache.subscriber.AbstractQueryCacheEndToEndConstructor
Here order of method calls should not change.
createNewRecordStore(String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
createNewRecordStore(String, int) - Method in class com.hazelcast.cache.impl.CacheService
 
createNewRegistry(CPGroupId) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchService
 
createNewRegistry(CPGroupId) - Method in class com.hazelcast.cp.internal.datastructures.lock.LockService
 
createNewRegistry(CPGroupId) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreService
 
createNewRegistry(CPGroupId) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
Creates a registry for the given Raft group.
createNewResource(CPGroupId, String) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchRegistry
 
createNewResource(CPGroupId, String) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreRegistry
 
createNewResource(CPGroupId, String) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
createNewSession(CPGroupId, Address, String, CPSession.CPSessionOwnerType, long) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
createNodeExtension(Node) - Method in class com.hazelcast.instance.impl.DefaultNodeContext
 
createNodeExtension(Node) - Method in interface com.hazelcast.instance.impl.NodeContext
 
createNodeState(MemberStateImpl) - Method in class com.hazelcast.internal.management.TimedMemberStateFactory
 
createObjectDataInput(byte[]) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
createObjectDataInput(Data) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
createObjectDataInput(byte[]) - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
 
createObjectDataInput(Data) - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
 
createObjectDataInputStream(InputStream, InternalSerializationService) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
 
createObjectDataOutput(int) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
createObjectDataOutput() - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
createObjectDataOutput(int) - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
 
createObjectDataOutput() - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
 
createObjectDataOutputStream(OutputStream, InternalSerializationService) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
 
createObjectName(String, String) - Method in class com.hazelcast.internal.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.client.impl.protocol.task.cache.CacheAssignAndGetUuidsOperationFactory
 
createOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsOperationFactory
 
createOperation() - Method in class com.hazelcast.map.impl.operation.AddIndexOperationFactory
 
createOperation() - Method in class com.hazelcast.map.impl.operation.ClearOperationFactory
 
createOperation() - Method in class com.hazelcast.map.impl.operation.ContainsValueOperationFactory
 
createOperation() - Method in class com.hazelcast.map.impl.operation.EvictAllOperationFactory
 
createOperation() - Method in class com.hazelcast.map.impl.operation.IsEmptyOperationFactory
 
createOperation() - Method in class com.hazelcast.map.impl.operation.IsPartitionLoadedOperationFactory
 
createOperation() - Method in class com.hazelcast.map.impl.operation.KeyLoadStatusOperationFactory
 
createOperation() - Method in class com.hazelcast.map.impl.operation.MapFlushOperationFactory
 
createOperation() - Method in class com.hazelcast.map.impl.operation.MapGetAllOperationFactory
 
createOperation() - Method in class com.hazelcast.map.impl.operation.MapLoadAllOperationFactory
 
createOperation() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperationFactory
 
createOperation() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperationFactory
 
createOperation() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperationFactory
 
createOperation() - Method in class com.hazelcast.map.impl.operation.SizeOperationFactory
 
createOperation() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.MadePublishableOperationFactory
 
createOperation() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
 
createOperation() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperationFactory
 
createOperation() - Method in class com.hazelcast.replicatedmap.impl.operation.PutAllOperationFactory
 
createOperation() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnPartitionOperationFactory
 
createOperation() - Method in class com.hazelcast.spi.impl.operationservice.BinaryOperationFactory
 
createOperation() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionAwareOperationFactory
 
createOperation() - Method in interface com.hazelcast.spi.impl.operationservice.OperationFactory
Creates the operation.
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.cache.CacheAssignAndGetUuidsMessageTask
 
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.MapAssignAndGetUuidsMessageTask
 
createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearMessageTask
 
createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsValueMessageTask
 
createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictAllMessageTask
 
createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnAllKeysMessageTask
 
createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeysMessageTask
 
createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
 
createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
 
createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapMadePublishableMessageTask
 
createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveAllMessageTask
 
createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSizeMessageTask
 
createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapClearMessageTask
 
createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsValueMessageTask
 
createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
 
createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
 
createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
 
createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
 
createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
 
createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
 
createOperationProvider(String, InMemoryFormat) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
createOperationProvider(String, InMemoryFormat) - Method in class com.hazelcast.cache.impl.CacheService
 
createOperationStats() - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
createOperationStats() - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
createOperationStats() - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Creates a new per-operation stats instance.
createOperationSupplier() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMultiTargetMessageTask
 
createOperationSupplier() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxiesMessageTask
 
createOperationSupplier() - Method in class com.hazelcast.client.impl.protocol.task.DeployClassesMessageTask
 
createOperationSupplier() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddInterceptorMessageTask
 
createOperationSupplier() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
 
createOperationSupplier() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XACollectTransactionsMessageTask
 
createOutboundHandlers(EndpointQualifier, TcpIpConnection, IOService) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
createOutboundHandlers(EndpointQualifier, TcpIpConnection, IOService) - Method in interface com.hazelcast.instance.impl.NodeExtension
Creates a OutboundHandler for given Connection instance.
createOutboundHandlers(EndpointQualifier, TcpIpConnection) - Method in interface com.hazelcast.internal.nio.IOService
 
createOutboundHandlers(EndpointQualifier, TcpIpConnection) - Method in class com.hazelcast.internal.nio.NodeIOService
 
createOutput(int, InternalSerializationService) - Method in interface com.hazelcast.internal.serialization.InputOutputFactory
 
createParameters(Node) - Method in class com.hazelcast.internal.util.PhoneHome
 
createParser(JsonFactory) - Method in class com.hazelcast.internal.serialization.impl.DataInputNavigableJsonAdapter
 
createParser(JsonFactory) - Method in class com.hazelcast.internal.serialization.impl.NavigableJsonInputAdapter
Creates a parser from given factory
createParser(JsonFactory) - Method in class com.hazelcast.internal.serialization.impl.StringNavigableJsonAdapter
 
createParser(Object) - Method in class com.hazelcast.query.impl.getters.JsonDataGetter
 
createPartitionOperation(int) - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperationFactory
 
createPartitionOperation(int) - Method in class com.hazelcast.map.impl.operation.MergeOperationFactory
 
createPartitionOperation(int) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperationFactory
 
createPartitionOperation(int) - Method in class com.hazelcast.map.impl.operation.PutAllPartitionAwareOperationFactory
 
createPartitionOperation(int) - Method in class com.hazelcast.replicatedmap.impl.operation.MergeOperationFactory
 
createPartitionOperation(int) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionAwareOperationFactory
This method can be called both caller and runner nodes.
createPartitionRunner(int) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationRunnerFactory
Creates an OperationRunner for a given partition.
createPartitionState() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
createPartitionState() - Method in interface com.hazelcast.internal.partition.InternalPartitionService
Creates the current partition runtime state.
createPartitionStateInternal() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
Returns a copy of the partition table or null if not initialized.
createPartitionTableView() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
createPartitionTableView() - Method in interface com.hazelcast.internal.partition.InternalPartitionService
Creates an immutable/readonly view of partition table.
createPartitionTarget(int) - Static method in class com.hazelcast.map.impl.query.Target
 
createPartitionWideEntryOperationFactory(String, EntryProcessor) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createPartitionWideEntryOperationFactory(String, EntryProcessor) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createPartitionWideEntryWithPredicateOperationFactory(String, EntryProcessor, Predicate) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createPartitionWideEntryWithPredicateOperationFactory(String, EntryProcessor, Predicate) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createPattern(NavigableJsonInputAdapter, JsonSchemaNode, JsonPathCursor) - Static method in class com.hazelcast.json.internal.JsonSchemaHelper
Creates a JsonPattern for given query path.
createPerIndexStats(boolean, boolean) - Method in class com.hazelcast.monitor.impl.GlobalIndexesStats
 
createPerIndexStats(boolean, boolean) - Method in interface com.hazelcast.monitor.impl.IndexesStats
Creates a new instance of internal per-index stats.
createPerIndexStats(boolean, boolean) - Method in class com.hazelcast.monitor.impl.PartitionIndexesStats
 
createPortableReader(Data) - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1
 
createPortableReader(Data) - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
 
CreateProxiesMessageTask - Class in com.hazelcast.client.impl.protocol.task
 
CreateProxiesMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.CreateProxiesMessageTask
 
createProxy(String, String) - Method in class com.hazelcast.client.cp.internal.datastructures.proxy.ClientRaftProxyFactory
 
createProxy(String) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchService
 
createProxy(String) - Method in class com.hazelcast.cp.internal.datastructures.lock.LockService
 
createProxy(String) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreService
 
createProxy(String) - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueService
 
createProxy(String) - Method in interface com.hazelcast.cp.internal.datastructures.spi.RaftRemoteService
Creates a proxy for a CP data structure.
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
 
createPublisherAccumulator(AccumulatorInfo) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheEndToEndConstructor
 
createPublisherAccumulator(AccumulatorInfo) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheEndToEndConstructor
 
createPublisherAccumulator(AccumulatorInfo) - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheEndToEndConstructor
Creates a new publisher-accumulator according to AccumulatorInfo.
createPurgeTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.AllowedDuringPassiveStateTransactionImpl
 
createPurgeTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
createPutAllOperation(List<Map.Entry<Data, Data>>, ExpiryPolicy, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
 
createPutAllOperation(List<Map.Entry<Data, Data>>, ExpiryPolicy, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
 
createPutAllOperation(String, MapEntries) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createPutAllOperation(String, MapEntries) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createPutAllOperationFactory(String, int[], MapEntries[]) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createPutAllOperationFactory(String, int[], MapEntries[]) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createPutFromLoadAllOperation(String, List<Data>, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createPutFromLoadAllOperation(String, List<Data>, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createPutIfAbsentOperation(Data, Data, ExpiryPolicy, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
 
createPutIfAbsentOperation(Data, Data, ExpiryPolicy, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
 
createPutIfAbsentOperation(String, Data, Data, long, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createPutIfAbsentOperation(String, Data, Data, long, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createPutOperation(Data, Data, ExpiryPolicy, boolean, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
 
createPutOperation(Data, Data, ExpiryPolicy, boolean, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
 
createPutOperation(String, Data, Data, long, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createPutOperation(String, Data, Data, long, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createPutTransientOperation(String, Data, Data, long, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createPutTransientOperation(String, Data, Data, long, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createQueryCacheEventData(Data, Data, long, int, int) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.CustomTypeFactory
 
createQueryCacheListenerAdaptor(MapListener) - Static method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheEventListenerAdapters
Wraps a user defined MapListener into a ListenerAdapter.
createQueryOperation(Query) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createQueryOperation(Query) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createQueryPartitionOperation(Query) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createQueryPartitionOperation(Query) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createRaftGroup(String, Collection<RaftEndpoint>, long) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
createRaftGroup(String) - Method in class com.hazelcast.cp.internal.RaftInvocationManager
 
createRaftGroup(String, int) - Method in class com.hazelcast.cp.internal.RaftInvocationManager
 
createRaftGroupForProxy(String) - Method in class com.hazelcast.cp.internal.RaftService
 
createRaftGroupForProxyAsync(String) - Method in class com.hazelcast.cp.internal.RaftService
 
CreateRaftGroupMessageTask - Class in com.hazelcast.cp.internal.datastructures.spi.client
Client message task for Raft group creation
CreateRaftGroupMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.spi.client.CreateRaftGroupMessageTask
 
CreateRaftGroupOp - Class in com.hazelcast.cp.internal.raftop.metadata
Creates a new Raft group with the given name and the members and returns its ID.
CreateRaftGroupOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.CreateRaftGroupOp
 
CreateRaftGroupOp(String, Collection<RaftEndpoint>) - Constructor for class com.hazelcast.cp.internal.raftop.metadata.CreateRaftGroupOp
 
createRaftNode(CPGroupId, Collection<RaftEndpoint>) - Method in class com.hazelcast.cp.internal.RaftService
 
CreateRaftNodeOp - Class in com.hazelcast.cp.internal.raftop.metadata
On creation of a new Raft group or a membership change in an existing Raft group, this operation is sent to the new members of the Raft group to initiate the RaftNode on the new member.
CreateRaftNodeOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.CreateRaftNodeOp
 
CreateRaftNodeOp(CPGroupId, Collection<RaftEndpoint>) - Constructor for class com.hazelcast.cp.internal.raftop.metadata.CreateRaftNodeOp
 
createRaftStateStore(RaftGroupId, LogFileStructure) - Method in interface com.hazelcast.cp.internal.persistence.CPPersistenceService
Creates a RaftStateStore that is going to be used by the local Raft node of the given CP group.
createRaftStateStore(RaftGroupId, LogFileStructure) - Method in class com.hazelcast.cp.internal.persistence.NopCPPersistenceService
 
createRecord(Object, long, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
createRecord(long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
createRecord(Object, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
createRecord(Data, Object, long, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
createRecord(Data, Object, long, long, boolean, int, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
createRecord(Object, long, long) - Method in class com.hazelcast.cache.impl.CacheRecordStore
 
createRecord(V) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
createRecord(V) - Method in class com.hazelcast.internal.nearcache.impl.store.NearCacheDataRecordStore
 
createRecord(V) - Method in class com.hazelcast.internal.nearcache.impl.store.NearCacheObjectRecordStore
 
createRecord(Data) - Method in class com.hazelcast.map.impl.querycache.subscriber.record.DataQueryCacheRecordFactory
 
createRecord(Data) - Method in class com.hazelcast.map.impl.querycache.subscriber.record.ObjectQueryCacheRecordFactory
 
createRecord(Data) - Method in interface com.hazelcast.map.impl.querycache.subscriber.record.QueryCacheRecordFactory
Creates new QueryCacheRecord.
createRecord(Data, Object, long, long, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
createRecordCacheMap() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
createRecordCacheMap() - Method in class com.hazelcast.cache.impl.CacheRecordStore
 
createRecordStore(MapContainer, int, MapKeyLoader) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
createRecordStoreMutationObservers(String, int) - Method in interface com.hazelcast.map.impl.MapServiceContext
Returns the collection of the RecordStoreMutationObservers for the given map's partition that need to be added in record store construction time in order to ensure no RecordStore mutations are missed.
createRecordStoreOnDemand - Variable in class com.hazelcast.map.impl.operation.MapOperation
 
createRecordWithExpiry(Data, Object, long, long, boolean, int, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
createRecordWithExpiry(Data, Object, long, long, boolean, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
createRecordWithExpiry(Data, Object, ExpiryPolicy, long, boolean, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
createRecordWithExpiry(Data, Object, ExpiryPolicy, long, boolean, int, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
createRecoveryOperation(String, String, long, int) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientSubscriberContextSupport
 
createRecoveryOperation(String, String, long, int) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeSubscriberContextSupport
 
createRecoveryOperation(String, String, long, int) - Method in interface com.hazelcast.map.impl.querycache.subscriber.SubscriberContextSupport
Creates recovery operation for event loss cases.
createRemoteMerkleTreeView(DataInput) - Static method in class com.hazelcast.wan.impl.merkletree.MerkleTreeUtil
Creates a RemoteMerkleTreeView by reading the hashes of the leaves of a Merkle tree from the provided DataInput
createRemoveAllOperationFactory(Set<Data>, Integer) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
 
createRemoveAllOperationFactory(Set<Data>, Integer) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
 
createRemoveIfSameOperation(String, Data, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createRemoveIfSameOperation(String, Data, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createRemoveOperation(Data, Data, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
 
createRemoveOperation(Data, Data, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
 
createRemoveOperation(String, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createRemoveOperation(String, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createReplaceIfSameOperation(String, Data, Data, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createReplaceIfSameOperation(String, Data, Data, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createReplaceOperation(Data, Data, Data, ExpiryPolicy, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
 
createReplaceOperation(Data, Data, Data, ExpiryPolicy, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
 
createReplaceOperation(String, Data, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createReplaceOperation(String, Data, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createReplicateTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.AllowedDuringPassiveStateTransactionImpl
 
createReplicateTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
createResult(SerializationService, long) - Method in class com.hazelcast.map.impl.query.Query
 
createResultSet() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalReadOperation
 
createResultSet() - Method in class com.hazelcast.internal.journal.EventJournalReadOperation
 
createResultSet() - Method in class com.hazelcast.map.impl.journal.MapEventJournalReadOperation
 
createRollbackTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.AllowedDuringPassiveStateTransactionImpl
 
createRollbackTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
createSamplingEntry(Data, CacheRecord) - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap
 
createSamplingEntry(K, V) - Method in class com.hazelcast.internal.nearcache.impl.store.HeapNearCacheRecordMap
 
createSamplingEntry(K, V) - Method in class com.hazelcast.internal.util.SampleableConcurrentHashMap
 
createSamplingEntry(Data, QueryCacheRecord) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordHashMap
 
createSamplingEntry(Data, R) - Method in class com.hazelcast.map.impl.recordstore.StorageSCHM
 
createSchema(JsonParser) - Static method in class com.hazelcast.json.internal.JsonSchemaHelper
Creates a description out of a JsonValue.
createSecureCallable(Subject, Callable<V>) - Method in interface com.hazelcast.security.SecurityContext
Creates secure callable that runs in a sandbox.
createSecureCallable(Subject, Runnable) - Method in interface com.hazelcast.security.SecurityContext
Creates secure callable that runs in a sandbox.
createSerializationService(byte) - Method in interface com.hazelcast.client.impl.ClientExtension
Creates a InternalSerializationService instance to be used by this client.
createSerializationService(byte) - Method in class com.hazelcast.client.impl.clientside.DefaultClientExtension
 
createSerializationService() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
createSerializationService() - Method in interface com.hazelcast.instance.impl.NodeExtension
Creates a SerializationService instance to be used by this Node.
createSerializationService(InputOutputFactory, Supplier<RuntimeException>) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
createSerializer() - Method in interface com.hazelcast.nio.serialization.SerializerHook
Creates a new serializer for the serialization type
createService(Class<T>) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
createService(Class<T>) - Method in interface com.hazelcast.instance.impl.NodeExtension
Creates a service which is an implementation of given type parameter.
createServiceDescriptors() - Method in class com.hazelcast.cp.internal.datastructures.RaftDataServiceDescriptorProvider
 
createServiceDescriptors() - Method in class com.hazelcast.cp.internal.RaftServiceDescriptorProvider
 
createServiceDescriptors() - Method in class com.hazelcast.internal.longregister.LongRegisterServiceDescriptorProvider
 
createServiceDescriptors() - Method in interface com.hazelcast.spi.impl.servicemanager.ServiceDescriptorProvider
 
createServiceProxyFactory(Class<T>) - Method in interface com.hazelcast.client.impl.ClientExtension
Creates a ClientProxyFactory for the supplied service class.
createServiceProxyFactory(Class<T>) - Method in class com.hazelcast.client.impl.clientside.DefaultClientExtension
 
CreateSessionMessageTask - Class in com.hazelcast.cp.internal.session.client
Client message task for CreateSessionOp
CreateSessionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.session.client.CreateSessionMessageTask
 
CreateSessionOp - Class in com.hazelcast.cp.internal.session.operation
Creates a new session for the given endpoint and returns its id.
CreateSessionOp() - Constructor for class com.hazelcast.cp.internal.session.operation.CreateSessionOp
 
CreateSessionOp(Address, String, CPSession.CPSessionOwnerType, long) - Constructor for class com.hazelcast.cp.internal.session.operation.CreateSessionOp
 
createSetExpiryPolicyOperation(List<Data>, Data) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
 
createSetExpiryPolicyOperation(List<Data>, Data) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
 
createSetOperation(String, Data, Data, long, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createSetOperation(String, Data, Data, long, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createSetTtlOperation(String, Data, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createSetTtlOperation(String, Data, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createSimpleEntryView(Data, Data, long, long, long, long, long, long, long, long, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.CustomTypeFactory
 
createSimpleEntryView() - Static method in class com.hazelcast.map.impl.EntryViews
 
createSimpleEntryView(K, V, Record) - 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
 
createSocketConnection(Address) - Method in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
createSocketInterceptor() - Method in interface com.hazelcast.client.impl.ClientExtension
Creates a SocketInterceptor to be used by this client if available, otherwise returns null
createSocketInterceptor(SocketInterceptorConfig) - Method in interface com.hazelcast.client.impl.ClientExtension
Create socket interceptor according to given config
createSocketInterceptor() - Method in class com.hazelcast.client.impl.clientside.DefaultClientExtension
 
createSocketInterceptor(SocketInterceptorConfig) - Method in class com.hazelcast.client.impl.clientside.DefaultClientExtension
 
createSplitBrainJoinMessage() - Method in class com.hazelcast.instance.impl.Node
 
createStats(String) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
createStorage(RecordFactory<R>, InMemoryFormat) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
createStoreEvent(E) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.StoreEvent
 
createSubResult() - Method in class com.hazelcast.map.impl.query.AggregationResult
 
createSubResult() - Method in class com.hazelcast.map.impl.query.QueryResult
 
createSubResult() - Method in interface com.hazelcast.map.impl.query.Result
Creates a new empty sub result of the same type as this result.
createSubscriberAccumulator(AccumulatorInfo) - Method in class com.hazelcast.map.impl.querycache.subscriber.AbstractQueryCacheEndToEndConstructor
 
createSubscriberAccumulator(AccumulatorInfo) - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheEndToEndConstructor
Creates a new SubscriberAccumulator
createSubscriberAccumulatorFactory() - Method in class com.hazelcast.map.impl.querycache.subscriber.SubscriberRegistry
 
createSubscriberRegistry(String) - Method in class com.hazelcast.map.impl.querycache.subscriber.MapSubscriberRegistry
 
createTestIndexConfig(IndexType, String...) - Static method in class com.hazelcast.query.impl.IndexUtils
Create simple index definition with the given attributes and initialize it's name upfront.
createTextCommandService() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
createTextCommandService() - Method in interface com.hazelcast.instance.impl.NodeExtension
 
createThread(Runnable) - Method in class com.hazelcast.internal.util.executor.AbstractExecutorThreadFactory
 
createThread(Runnable) - Method in class com.hazelcast.internal.util.executor.PoolExecutorThreadFactory
 
createThread(Runnable, String, int) - Method in class com.hazelcast.internal.util.executor.PoolExecutorThreadFactory
 
createThread(Runnable) - Method in class com.hazelcast.internal.util.executor.SingleExecutorThreadFactory
 
createThread(Runnable, String, int) - Method in class com.hazelcast.internal.util.executor.UnblockablePoolExecutorThreadFactory
 
createThreadName(String, String) - Static method in class com.hazelcast.internal.util.ThreadUtil
Creates the threadname with prefix and notation.
createThreadPoolName(String, String) - Static method in class com.hazelcast.internal.util.ThreadUtil
Creates the threadpool name with prefix and notation.
createTimedExpiryPolicyFactoryConfig(int, CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.CustomTypeFactory
 
createTimedMemberState() - Method in class com.hazelcast.internal.management.TimedMemberStateFactory
 
createTimedMemberStateFactory(HazelcastInstanceImpl) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
createTimedMemberStateFactory(HazelcastInstanceImpl) - Method in interface com.hazelcast.instance.impl.NodeExtension
Creates a TimedMemberStateFactory for a given Hazelcast instance
createTransactionalObject(String, Transaction) - Method in class com.hazelcast.collection.impl.list.ListService
 
createTransactionalObject(String, Transaction) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
createTransactionalObject(String, Transaction) - Method in class com.hazelcast.collection.impl.set.SetService
 
createTransactionalObject(String, Transaction) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
createTransactionalObject(String, Transaction) - Method in interface com.hazelcast.internal.services.TransactionalService
 
createTransactionalObject(String, Transaction) - Method in class com.hazelcast.map.impl.MapService
 
createTransactionalObject(String, Transaction) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
createTryPutOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createTryPutOperation(String, Data, Data, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createTryRemoveOperation(String, Data, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createTryRemoveOperation(String, Data, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
CreateTxBackupLogOperation - Class in com.hazelcast.transaction.impl.operations
 
CreateTxBackupLogOperation() - Constructor for class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
 
CreateTxBackupLogOperation(UUID, UUID) - Constructor for class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
 
createTxnDeleteOperation(String, Data, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createTxnDeleteOperation(String, Data, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createTxnLockAndGetOperation(String, Data, long, long, UUID, boolean, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createTxnLockAndGetOperation(String, Data, long, long, UUID, boolean, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createTxnSetOperation(String, Data, Data, long, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
createTxnSetOperation(String, Data, Data, long, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
 
createUrlEndpoint(String, String) - Static method in class com.hazelcast.client.impl.spi.impl.discovery.HazelcastCloudDiscovery
 
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.
createWriter(Writer) - Method in class com.hazelcast.internal.json.PrettyPrint
 
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.
creationTime - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
This field is not mutated (read only) so no need to define it as volatile.
creationTime - Variable in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
creationTime - Variable in class com.hazelcast.collection.impl.collection.CollectionItem
 
creationTime - Variable in class com.hazelcast.collection.impl.queue.QueueItem
 
creationTime() - Method in class com.hazelcast.cp.internal.session.CPSessionInfo
 
creationTime() - Method in interface com.hazelcast.cp.session.CPSession
Returns the timestamp of when the session was created
creationTime - Variable in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
creationTime - Variable in class com.hazelcast.map.impl.record.RecordInfo
 
credentials - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec.RequestParameters
Secret byte array for authentication.
credentials - Variable in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
 
Credentials - Interface in com.hazelcast.security
Credentials represents an identity to be authenticated.
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
 
CredentialsIdentityConfig - Class in com.hazelcast.config.security
Identity configuration which just holds given credentials instance.
CredentialsIdentityConfig(Credentials) - Constructor for class com.hazelcast.config.security.CredentialsIdentityConfig
 
CSHARP - Static variable in class com.hazelcast.client.impl.ClientTypes
CSHARP client protocol ID
CSHARP_CLR_SERIALIZATION_TYPE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
current() - Method in class com.hazelcast.client.impl.clientside.ClientDiscoveryService
 
CURRENT_CLUSTER_VERSION - Static variable in class com.hazelcast.internal.cluster.Versions
 
CURRENT_VM - Static variable in enum com.hazelcast.internal.util.JavaVm
 
currentFile() - Method in class com.hazelcast.internal.diagnostics.Diagnostics
 
currentIndex - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
currentIndex - Variable in class com.hazelcast.map.impl.iterator.AbstractMapPartitionIterator
 
currentIndex - Variable in class com.hazelcast.map.impl.iterator.AbstractMapQueryPartitionIterator
 
currentSequence(String, int) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataGenerator
 
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.internal.util.Clock.ClockImpl
 
currentTimeMillis() - Static method in class com.hazelcast.internal.util.Clock
Returns the current time in ms for the configured Clock.ClockImpl
currentValue - Variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveCodec.RequestParameters
value expected to be associated with the specified key.
currentValue() - Method in class com.hazelcast.map.impl.mapstore.writebehind.NodeWideUsedCapacityCounter
 
cursor() - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
Provides a cursor over the map's entries.
cursor() - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
 
cursor() - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
 
cursor() - Method in interface com.hazelcast.internal.util.collection.LongSet
 
cursor() - Method in class com.hazelcast.internal.util.collection.LongSetHsa
 
cursor() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray12byteKey
Returns a cursor over all assigned slots in this array.
cursor() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray16byteKey
Returns a cursor over all assigned slots in this array.
cursor() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray8byteKey
Returns a cursor over all assigned slots in this array.
cursor() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray12byteKeyImpl
 
cursor() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyImpl
 
cursor() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray8byteKeyImpl
 
Cursor() - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase.Cursor
 
CursorIntKey2() - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase.CursorIntKey2
 
CursorLongKey2() - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase.CursorLongKey2
 
CUSTOM_ACCESS - Static variable in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
CustomByteAccessStrategy - Class in com.hazelcast.internal.memory.impl
A ByteAccessStrategy that works with a MemoryAccessor.
CustomTypeFactory - Class in com.hazelcast.client.impl.protocol.codec.builtin
 
CustomWanPublisherConfig - Class in com.hazelcast.config
Configuration object for a custom WAN publisher.
CustomWanPublisherConfig() - Constructor for class com.hazelcast.config.CustomWanPublisherConfig
 
CustomWanPublisherConfigDTO - Class in com.hazelcast.internal.management.dto
A JSON representation of CustomWanPublisherConfig.
CustomWanPublisherConfigDTO() - Constructor for class com.hazelcast.internal.management.dto.CustomWanPublisherConfigDTO
 
CustomWanPublisherConfigDTO(CustomWanPublisherConfig) - Constructor for class com.hazelcast.internal.management.dto.CustomWanPublisherConfigDTO
 
CyclicBuffer<E extends Sequenced> - Interface in com.hazelcast.map.impl.querycache.accumulator
A cyclic buffer to store Sequenced events.

D

data - Variable in class com.hazelcast.collection.impl.queue.QueueItem
 
data - Variable in class com.hazelcast.map.impl.operation.MapReplicationStateHolder
 
Data - Interface in com.hazelcast.nio.serialization
Data is basic unit of serialization.
DATA_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
A MemberSelector instance that selects only data members that own a partition
DATA_OFFSET - Static variable in class com.hazelcast.internal.serialization.impl.HeapData
 
DataAwareEntryEvent<K,V> - Class in com.hazelcast.map.impl
 
DataAwareEntryEvent(Member, int, String, Data, Data, Data, Data, SerializationService) - Constructor for class com.hazelcast.map.impl.DataAwareEntryEvent
 
DataAwareItemEvent<E> - Class in com.hazelcast.collection.impl.common
An ItemEvent that is able to store a Data.
DataAwareItemEvent(String, ItemEventType, Data, Member, SerializationService) - Constructor for class com.hazelcast.collection.impl.common.DataAwareItemEvent
 
DataAwareMessage - Class in com.hazelcast.topic.impl
 
DataAwareMessage(String, Data, long, Member, SerializationService) - Constructor for class com.hazelcast.topic.impl.DataAwareMessage
 
DataCodec - Class in com.hazelcast.client.impl.protocol.codec.builtin
 
DataInputNavigableJsonAdapter - Class in com.hazelcast.internal.serialization.impl
 
DataInputNavigableJsonAdapter(BufferObjectDataInput, int) - Constructor for class com.hazelcast.internal.serialization.impl.DataInputNavigableJsonAdapter
 
dataKey - Variable in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
 
dataKey - Variable in class com.hazelcast.map.impl.event.EntryEventData
 
dataKey - Variable in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
 
dataKey - Variable in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
 
dataKey - Variable in class com.hazelcast.map.impl.operation.PutBackupOperation
 
dataKey - Variable in class com.hazelcast.map.impl.operation.ReadonlyKeyBasedMapOperation
 
dataKey - Variable in class com.hazelcast.multimap.impl.operations.AbstractKeyBasedMultiMapOperation
 
dataList - Variable in class com.hazelcast.client.impl.protocol.codec.QueueAddAllCodec.RequestParameters
Collection containing elements to be added to this collection
dataList - Variable in class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRemoveAllCodec.RequestParameters
Collection containing elements to be removed from this collection
dataList - Variable in class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRetainAllCodec.RequestParameters
collection containing elements to be retained in this collection
dataList - Variable in class com.hazelcast.client.impl.protocol.codec.QueueContainsAllCodec.RequestParameters
Collection to be checked for containment in this collection
dataMemberCount - Variable in class com.hazelcast.internal.cluster.impl.JoinMessage
 
dataMergingValue - Variable in class com.hazelcast.map.impl.event.EntryEventData
 
dataNewValue - Variable in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
 
dataNewValue - Variable in class com.hazelcast.map.impl.event.EntryEventData
 
dataNewValue - Variable in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
 
dataOldValue - Variable in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
 
dataOldValue - Variable in class com.hazelcast.map.impl.event.EntryEventData
 
dataOldValue - Variable in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
 
dataOldValue - Variable in class com.hazelcast.map.impl.operation.BaseRemoveOperation
 
DataQueryCacheRecordFactory - Class in com.hazelcast.map.impl.querycache.subscriber.record
Factory for DataQueryCacheRecord.
DataQueryCacheRecordFactory(SerializationService) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.record.DataQueryCacheRecordFactory
 
DataRecordFactory - Class in com.hazelcast.map.impl.record
 
DataRecordFactory(MapConfig, SerializationService, PartitioningStrategy) - Constructor for class com.hazelcast.map.impl.record.DataRecordFactory
 
DataReplicatedRecordStore - Class in com.hazelcast.replicatedmap.impl.record
This is a Data based ReplicatedRecordStore implementation
DataReplicatedRecordStore(String, ReplicatedMapService, int) - Constructor for class com.hazelcast.replicatedmap.impl.record.DataReplicatedRecordStore
 
DataSerializable - Interface in com.hazelcast.nio.serialization
DataSerializable is a serialization method alternative to standard Java serialization.
dataSerializableFactories - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
DataSerializableFactory - Interface in com.hazelcast.nio.serialization
DataSerializableFactory is used to create IdentifiedDataSerializable instances during de-serialization.
dataSerializerAdapter - Variable in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
DataSerializerHook - Interface in com.hazelcast.internal.serialization
 
dataSize() - Method in class com.hazelcast.internal.serialization.impl.HeapData
 
dataSize() - Method in interface com.hazelcast.nio.serialization.Data
Returns size of internal binary data in bytes
DataStructureAdapter<K,V> - Interface in com.hazelcast.internal.adapter
Abstracts the Hazelcast data structures with Near Cache support for the Near Cache usage.
DataStructureAdapter.DataStructureMethods - Enum in com.hazelcast.internal.adapter
Contains all methods of DataStructureAdapter.
DataStructureAdapterMethod - Interface in com.hazelcast.internal.adapter
Defines the signature of a method in DataStructureAdapter to search for available methods.
dataToValue(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
dataToValue(Data) - Method in class com.hazelcast.cache.impl.CacheRecordStore
 
DataType - Enum in com.hazelcast.internal.serialization
Defines type of the Data: heap or native.
dataValue - Variable in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
 
dataValue - Variable in class com.hazelcast.map.impl.operation.PutBackupOperation
 
DATE_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
DateSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.DateSerializer
 
deactivate() - Method in interface com.hazelcast.osgi.impl.HazelcastInternalOSGiService
Deactivates the service.
deactivate(Operation) - Static method in class com.hazelcast.spi.impl.operationservice.OperationAccessor
Marks the supplied operation as "not active".
DeadlineClusterFailureDetector - Class in com.hazelcast.internal.cluster.fd
Deadline based failure detector.
DeadlineClusterFailureDetector(long) - Constructor for class com.hazelcast.internal.cluster.fd.DeadlineClusterFailureDetector
 
DeclarativeConfigUtil - Class in com.hazelcast.internal.config
Utility class for handling declarative configuration files.
decode(ClientMessage.Frame) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ByteArrayCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ByteArrayCodec
 
decode(ClientMessage.Frame) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.DataCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.DataCodec
 
decode(ClientMessage.ForwardFrameIterator, Function<ClientMessage.ForwardFrameIterator, K>, Function<ClientMessage.ForwardFrameIterator, V>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.EntryListCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.EntryListIntegerLongCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.EntryListIntegerUUIDCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.EntryListLongByteArrayCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.EntryListUUIDLongCodec
 
decode(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ErrorsCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ListIntegerCodec
 
decode(ClientMessage.Frame) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ListIntegerCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ListLongCodec
 
decode(ClientMessage.Frame) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ListLongCodec
 
decode(ClientMessage.ForwardFrameIterator, Function<ClientMessage.ForwardFrameIterator, T>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ListMultiFrameCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ListScheduledTaskHandlerCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ListUUIDCodec
 
decode(ClientMessage.Frame) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ListUUIDCodec
 
decode(ClientMessage.Frame) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.LongArrayCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.LongArrayCodec
 
decode(ClientMessage.ForwardFrameIterator, Function<ClientMessage.ForwardFrameIterator, K>, Function<ClientMessage.ForwardFrameIterator, V>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.MapCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.StringCodec
 
decode(ClientMessage.Frame) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.StringCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.AddressCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.AttributeConfigCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.CacheConfigHolderCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.CacheEventDataCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.CacheSimpleEntryListenerConfigCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.DistributedObjectInfoCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.DurationConfigCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.ErrorHolderCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.EventJournalConfigCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.EvictionConfigHolderCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.HotRestartConfigCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.IndexConfigCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.ListenerConfigHolderCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.MapStoreConfigHolderCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.MemberCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.MergePolicyConfigCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.MerkleTreeConfigCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.NearCacheConfigHolderCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.NearCachePreloaderConfigCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.PredicateConfigHolderCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.QueryCacheConfigHolderCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.QueryCacheEventDataCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.QueueStoreConfigHolderCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.RaftGroupIdCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.RingbufferStoreConfigHolderCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.ScheduledTaskHandlerCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.SimpleEntryViewCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.StackTraceElementCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.TimedExpiryPolicyFactoryConfigCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.WanReplicationRefCodec
 
decode(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.XidCodec
 
decode(String) - Method in enum com.hazelcast.config.security.TokenEncoding
 
decodeAddResponse(ClientMessage) - Method in interface com.hazelcast.client.impl.spi.impl.ListenerMessageCodec
 
decodeBoolean(byte[], int) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
decodeByte(byte[], int) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
decodeClientMessage(ClientMessage) - Method in interface com.hazelcast.client.impl.clientside.ClientMessageDecoder
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AddBackupListenerMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionListenerMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
 
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.CacheAddNearCacheInvalidationListenerTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsMessageTask
 
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.CacheEventJournalReadTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalSubscribeTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheFetchNearCacheInvalidationMetadataTask
 
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.CacheIterateEntriesMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutAllMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutIfAbsentMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheReplaceMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSetExpiryPolicyMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSizeMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.Pre38CacheAddInvalidationListenerTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorAddMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorEstimateMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ClientStatisticsMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterAddMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetConfiguredReplicaCountMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.CreateProxiesMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.DeployClassesMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddCacheConfigMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddCardinalityEstimatorConfigMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddDurableExecutorConfigMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddExecutorConfigMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddFlakeIdGeneratorConfigMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddListConfigMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddMapConfigMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddMultiMapConfigMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddQueueConfigMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddReliableTopicConfigMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddReplicatedMapConfigMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddRingbufferConfigMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddScheduledExecutorConfigMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddSetConfigMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddTopicConfigMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorDisposeResultMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorIsShutdownMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveAndDisposeResultMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveResultMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorShutdownMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorSubmitToPartitionMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnAddressMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnPartitionMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.IsFailoverSupportedMessageTask
 
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.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.MapAddListenerMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddNearCacheInvalidationListenerMessageTask
 
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.MapAggregateMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateWithPredicateMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsMessageTask
 
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.MapDestroyCacheMessageTask
 
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.MapEventJournalReadTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEventJournalSubscribeTask
 
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.MapFetchEntriesMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchKeysMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchNearCacheInvalidationMetadataTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchWithQueryMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetEntryViewMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapMadePublishableMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionWithPredicateMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateWithValueMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentWithMaxIdleMessageTask
 
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.MapPutTransientWithMaxIdleMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutWithMaxIdleMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveAllMessageTask
 
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.MapSetReadCursorMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetTtlMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetWithMaxIdleMessageTask
 
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.map.Pre38MapAddNearCacheEntryListenerMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.metrics.ReadMetricsMessageTask
 
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.MultiMapDeleteMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapGetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapPutMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValueCountMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddAllMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueClearMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRemoveAllMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRetainAllMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsAllMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMaxSizeMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIsEmptyMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIteratorMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueOfferMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePeekMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePollMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePutMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemainingCapacityMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueSizeMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueTakeMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddAllMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferCapacityMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferHeadSequenceMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadManyMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadOneMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferRemainingCapacityMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferSizeMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferTailSequenceMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorGetAllScheduledMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorShutdownMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToAddressMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToPartitionMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromAddressMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromPartitionMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromAddressMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromPartitionMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromAddressMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromPartitionMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromAddressMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromPartitionMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromAddressMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromPartitionMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromAddressMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromPartitionMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromAddressMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromPartitionMessageTask
 
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
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.AddAndGetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.AlterMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.ApplyMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.CompareAndSetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetAndAddMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetAndSetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.ApplyMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.CompareAndSetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.ContainsMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.GetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.SetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.AwaitMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.CountDownMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.GetCountMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.GetRoundMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.TrySetCountMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.lock.client.GetLockOwnershipStateMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.lock.client.LockMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.lock.client.TryLockMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.lock.client.UnlockMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.AcquirePermitsMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.AvailablePermitsMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.ChangePermitsMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.DrainPermitsMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.GetSemaphoreTypeMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.InitSemaphoreMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.ReleasePermitsMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.spi.client.CreateRaftGroupMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.datastructures.spi.client.DestroyRaftObjectMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.session.client.CloseSessionMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.session.client.CreateSessionMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.session.client.GenerateThreadIdMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.cp.internal.session.client.HeartbeatSessionMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.flakeidgen.impl.client.NewIdBatchMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterAddAndGetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterDecrementAndGetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndAddMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndIncrementMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndSetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterIncrementAndGetMessageTask
 
decodeClientMessage(ClientMessage) - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterSetMessageTask
 
decodeContainsNullable(ClientMessage.ForwardFrameIterator, Function<ClientMessage.ForwardFrameIterator, T>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ListMultiFrameCodec
 
decodeEnum(byte[], int) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
decodeInt(byte[], int) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
decodeInteger(byte[], int) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
decodeLong(byte[], int) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
decodeNullable(ClientMessage.ForwardFrameIterator, Function<ClientMessage.ForwardFrameIterator, T>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.CodecUtil
 
decodeNullable(ClientMessage.ForwardFrameIterator, Function<ClientMessage.ForwardFrameIterator, K>, Function<ClientMessage.ForwardFrameIterator, V>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.EntryListCodec
 
decodeNullable(ClientMessage.ForwardFrameIterator, Function<ClientMessage.ForwardFrameIterator, T>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ListMultiFrameCodec
 
decodeNullable(ClientMessage.ForwardFrameIterator, Function<ClientMessage.ForwardFrameIterator, K>, Function<ClientMessage.ForwardFrameIterator, V>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.MapCodec
 
decodeRemoveResponse(ClientMessage) - Method in interface com.hazelcast.client.impl.spi.impl.ListenerMessageCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongAddAndGetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongAlterCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongApplyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongCompareAndSetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndAddCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndSetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefApplyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefCompareAndSetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefContainsCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefGetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefSetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddEntryListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddInvalidationListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddNearCacheInvalidationListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddPartitionLostListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAssignAndGetUuidsCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheClearCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheContainsKeyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheCreateConfigCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheDestroyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheEntryProcessorCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalReadCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalSubscribeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheFetchNearCacheInvalidationMetadataCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetAndRemoveCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetAndReplaceCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetConfigCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheIterateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheIterateEntriesCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheListenerRegistrationCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheLoadAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheManagementConfigCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CachePutAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CachePutCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CachePutIfAbsentCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllKeysCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveEntryListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveInvalidationListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemovePartitionLostListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheReplaceCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheSetExpiryPolicyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheSizeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorAddCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorEstimateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddDistributedObjectListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddMembershipListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionLostListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientCreateProxiesCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientCreateProxyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientDeployClassesCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientDestroyProxyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientGetDistributedObjectsCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientGetPartitionsCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientIsFailoverSupportedCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientLocalBackupListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientPingCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientRemoveAllListenersCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientRemoveDistributedObjectListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientRemovePartitionLostListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientStatisticsCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryAddListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryDestroyCacheCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryMadePublishableCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateWithValueCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQuerySetReadCursorCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchAwaitCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchCountDownCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetCountCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetRoundCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchTrySetCountCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CPGroupCreateCPGroupCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CPGroupDestroyCPObjectCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CPSessionCloseSessionCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CPSessionCreateSessionCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CPSessionGenerateThreadIdCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CPSessionHeartbeatSessionCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorDisposeResultCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorIsShutdownCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveAndDisposeResultCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveResultCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorShutdownCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorSubmitToPartitionCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCardinalityEstimatorConfigCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddDurableExecutorConfigCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddExecutorConfigCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddFlakeIdGeneratorConfigCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddListConfigCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMultiMapConfigCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddPNCounterConfigCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddQueueConfigCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReliableTopicConfigCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReplicatedMapConfigCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddRingbufferConfigCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddScheduledExecutorConfigCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddSetConfigCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddTopicConfigCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnAddressCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnPartitionCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceIsShutdownCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceShutdownCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToAddressCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToPartitionCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.FencedLockGetLockOwnershipCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.FencedLockLockCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.FencedLockTryLockCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.FencedLockUnlockCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.FlakeIdGeneratorNewIdBatchCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddAllWithIndexCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddWithIndexCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListClearCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListCompareAndRemoveAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListCompareAndRetainAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListContainsAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListContainsCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListGetAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListGetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListIndexOfCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListIsEmptyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListIteratorCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListLastIndexOfCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListListIteratorCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListRemoveCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListRemoveListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListRemoveWithIndexCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListSetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListSizeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListSubCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyWithPredicateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerWithPredicateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddIndexCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddInterceptorCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheEntryListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheInvalidationListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddPartitionLostListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAggregateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAggregateWithPredicateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAssignAndGetUuidsCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapClearCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapClearNearCacheCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapContainsKeyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapContainsValueCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapDeleteCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPagingPredicateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPredicateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEntrySetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEventJournalReadCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEventJournalSubscribeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEvictAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEvictCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnAllKeysCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeysCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapExecuteWithPredicateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapFetchEntriesCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapFetchKeysCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapFetchNearCacheInvalidationMetadataCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapFetchWithQueryCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapFlushCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapForceUnlockCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapGetAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapGetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapGetEntryViewCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapIsEmptyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapIsLockedCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapKeySetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPagingPredicateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPredicateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapLoadAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapLoadGivenKeysCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapLockCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapProjectCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapProjectWithPredicateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentWithMaxIdleCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutTransientCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutTransientWithMaxIdleCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutWithMaxIdleCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveEntryListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveIfSameCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveInterceptorCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemovePartitionLostListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapReplaceCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapReplaceIfSameCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapSetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapSetTtlCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapSetWithMaxIdleCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapSizeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapSubmitToKeyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapTryLockCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapTryPutCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapTryRemoveCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapUnlockCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapValuesCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapValuesWithPagingPredicateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapValuesWithPredicateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MetricsReadMetricsCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerToKeyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapClearCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsEntryCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsKeyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsValueCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapDeleteCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapEntrySetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapForceUnlockCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapGetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapIsLockedCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapKeySetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapLockCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapPutCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapSizeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapTryLockCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapUnlockCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapValueCountCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapValuesCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.PNCounterAddCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.PNCounterGetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.PNCounterGetConfiguredReplicaCountCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueAddAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueAddListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueClearCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRemoveAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRetainAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueContainsAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueContainsCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueDrainToCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueDrainToMaxSizeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueIsEmptyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueIteratorCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueOfferCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueuePeekCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueuePollCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueuePutCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueRemainingCapacityCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueRemoveCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueRemoveListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueSizeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueTakeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyWithPredicateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerWithPredicateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddNearCacheEntryListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapClearCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsKeyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsValueCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapEntrySetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapGetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapIsEmptyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapKeySetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveEntryListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapSizeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapValuesCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferAddAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferAddCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferCapacityCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferHeadSequenceCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferReadManyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferReadOneCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferRemainingCapacityCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferSizeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferTailSequenceCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromAddressCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromPartitionCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromAddressCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromPartitionCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetAllScheduledFuturesCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromAddressCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromPartitionCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromAddressCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromPartitionCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromAddressCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromPartitionCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromAddressCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromPartitionCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromAddressCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromPartitionCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorShutdownCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToAddressCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToPartitionCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreAcquireCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreAvailablePermitsCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreChangeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreDrainCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreGetSemaphoreTypeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreInitCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreReleaseCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetAddAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetAddCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetAddListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetClearCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetCompareAndRemoveAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetCompareAndRetainAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetContainsAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetContainsCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetGetAllCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetIsEmptyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetRemoveCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetRemoveListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetSizeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TopicAddMessageListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TopicPublishCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TopicRemoveMessageListenerCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalListAddCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalListRemoveCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalListSizeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsKeyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsValueCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapDeleteCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetForUpdateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapIsEmptyCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetWithPredicateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutIfAbsentCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveIfSameCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceIfSameCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSizeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesWithPredicateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapGetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapPutCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveEntryCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapSizeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapValueCountCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueOfferCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePeekCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePollCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueSizeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueTakeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalSetAddCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalSetRemoveCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalSetSizeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionCommitCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionCreateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionRollbackCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionClearRemoteCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionCollectTransactionsCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionCommitCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionCreateCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionFinalizeCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionPrepareCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionRollbackCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterAddAndGetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterDecrementAndGetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndAddCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndIncrementCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndSetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterIncrementAndGetCodec
 
decodeRequest(ClientMessage) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterSetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongAddAndGetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongAlterCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongApplyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongCompareAndSetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndAddCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndSetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefApplyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefCompareAndSetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefContainsCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefGetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefSetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddEntryListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddInvalidationListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddNearCacheInvalidationListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddPartitionLostListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAssignAndGetUuidsCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheClearCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheContainsKeyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheCreateConfigCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheDestroyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheEntryProcessorCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalReadCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalSubscribeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheFetchNearCacheInvalidationMetadataCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetAndRemoveCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetAndReplaceCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetConfigCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheIterateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheIterateEntriesCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheListenerRegistrationCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheLoadAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheManagementConfigCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CachePutAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CachePutCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CachePutIfAbsentCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllKeysCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveEntryListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveInvalidationListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemovePartitionLostListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheReplaceCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheSetExpiryPolicyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheSizeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorAddCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorEstimateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddDistributedObjectListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddMembershipListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionLostListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientCreateProxiesCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientCreateProxyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientDeployClassesCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientDestroyProxyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientGetDistributedObjectsCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientGetPartitionsCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientIsFailoverSupportedCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientLocalBackupListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientPingCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientRemoveAllListenersCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientRemoveDistributedObjectListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientRemovePartitionLostListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientStatisticsCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryAddListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryDestroyCacheCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryMadePublishableCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateWithValueCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQuerySetReadCursorCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchAwaitCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchCountDownCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetCountCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetRoundCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchTrySetCountCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CPGroupCreateCPGroupCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CPGroupDestroyCPObjectCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CPSessionCloseSessionCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CPSessionCreateSessionCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CPSessionGenerateThreadIdCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CPSessionHeartbeatSessionCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorDisposeResultCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorIsShutdownCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveAndDisposeResultCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveResultCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorShutdownCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorSubmitToPartitionCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCardinalityEstimatorConfigCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddDurableExecutorConfigCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddExecutorConfigCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddFlakeIdGeneratorConfigCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddListConfigCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMultiMapConfigCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddPNCounterConfigCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddQueueConfigCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReliableTopicConfigCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReplicatedMapConfigCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddRingbufferConfigCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddScheduledExecutorConfigCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddSetConfigCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddTopicConfigCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnAddressCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnPartitionCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceIsShutdownCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceShutdownCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToAddressCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToPartitionCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.FencedLockGetLockOwnershipCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.FencedLockLockCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.FencedLockTryLockCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.FencedLockUnlockCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.FlakeIdGeneratorNewIdBatchCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddAllWithIndexCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddWithIndexCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListClearCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListCompareAndRemoveAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListCompareAndRetainAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListContainsAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListContainsCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListGetAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListGetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListIndexOfCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListIsEmptyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListIteratorCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListLastIndexOfCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListListIteratorCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListRemoveCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListRemoveListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListRemoveWithIndexCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListSetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListSizeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ListSubCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyWithPredicateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerWithPredicateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddIndexCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddInterceptorCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheEntryListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheInvalidationListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddPartitionLostListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAggregateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAggregateWithPredicateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAssignAndGetUuidsCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapClearCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapClearNearCacheCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapContainsKeyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapContainsValueCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapDeleteCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPagingPredicateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPredicateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEntrySetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEventJournalReadCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEventJournalSubscribeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEvictAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEvictCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnAllKeysCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeysCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapExecuteWithPredicateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapFetchEntriesCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapFetchKeysCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapFetchNearCacheInvalidationMetadataCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapFetchWithQueryCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapFlushCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapForceUnlockCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapGetAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapGetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapGetEntryViewCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapIsEmptyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapIsLockedCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapKeySetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPagingPredicateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPredicateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapLoadAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapLoadGivenKeysCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapLockCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapProjectCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapProjectWithPredicateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentWithMaxIdleCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutTransientCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutTransientWithMaxIdleCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutWithMaxIdleCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveEntryListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveIfSameCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveInterceptorCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemovePartitionLostListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapReplaceCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapReplaceIfSameCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapSetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapSetTtlCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapSetWithMaxIdleCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapSizeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapSubmitToKeyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapTryLockCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapTryPutCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapTryRemoveCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapUnlockCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapValuesCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapValuesWithPagingPredicateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MapValuesWithPredicateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MetricsReadMetricsCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerToKeyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapClearCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsEntryCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsKeyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsValueCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapDeleteCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapEntrySetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapForceUnlockCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapGetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapIsLockedCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapKeySetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapLockCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapPutCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapSizeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapTryLockCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapUnlockCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapValueCountCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapValuesCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.PNCounterAddCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.PNCounterGetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.PNCounterGetConfiguredReplicaCountCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueAddAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueAddListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueClearCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRemoveAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRetainAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueContainsAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueContainsCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueDrainToCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueDrainToMaxSizeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueIsEmptyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueIteratorCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueOfferCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueuePeekCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueuePollCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueuePutCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueRemainingCapacityCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueRemoveCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueRemoveListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueSizeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueTakeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyWithPredicateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerWithPredicateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddNearCacheEntryListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapClearCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsKeyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsValueCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapEntrySetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapGetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapIsEmptyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapKeySetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveEntryListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapSizeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapValuesCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferAddAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferAddCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferCapacityCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferHeadSequenceCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferReadManyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferReadOneCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferRemainingCapacityCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferSizeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferTailSequenceCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromAddressCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromPartitionCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromAddressCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromPartitionCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetAllScheduledFuturesCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromAddressCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromPartitionCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromAddressCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromPartitionCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromAddressCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromPartitionCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromAddressCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromPartitionCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromAddressCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromPartitionCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorShutdownCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToAddressCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToPartitionCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreAcquireCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreAvailablePermitsCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreChangeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreDrainCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreGetSemaphoreTypeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreInitCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreReleaseCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetAddAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetAddCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetAddListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetClearCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetCompareAndRemoveAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetCompareAndRetainAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetContainsAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetContainsCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetGetAllCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetIsEmptyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetRemoveCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetRemoveListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.SetSizeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TopicAddMessageListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TopicPublishCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TopicRemoveMessageListenerCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalListAddCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalListRemoveCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalListSizeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsKeyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsValueCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapDeleteCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetForUpdateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapIsEmptyCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetWithPredicateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutIfAbsentCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveIfSameCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceIfSameCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSizeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesWithPredicateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapGetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapPutCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveEntryCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapSizeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapValueCountCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueOfferCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePeekCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePollCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueSizeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueTakeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalSetAddCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalSetRemoveCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalSetSizeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionCommitCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionCreateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionRollbackCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionClearRemoteCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionCollectTransactionsCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionCommitCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionCreateCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionFinalizeCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionPrepareCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionRollbackCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterAddAndGetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterDecrementAndGetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndAddCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndIncrementCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndSetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterIncrementAndGetCodec
 
decodeResponse(ClientMessage) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterSetCodec
 
decodeUUID(byte[], int) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
decompress(byte[]) - Static method in class com.hazelcast.internal.nio.IOUtil
 
decompressingIterator(byte[]) - Static method in class com.hazelcast.internal.metrics.managementcenter.MetricsCompressor
 
decreaseCacheEntryListenerCount() - Method in class com.hazelcast.cache.impl.CacheContext
 
decreaseEntryCount() - Method in class com.hazelcast.cache.impl.CacheContext
 
decreaseEntryCount(long) - Method in class com.hazelcast.cache.impl.CacheContext
 
decreaseHits(long) - Method in class com.hazelcast.monitor.impl.LocalRecordStoreStatsImpl
 
decreaseHits(long) - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Decreases the number of hits of the locally owned entries of this partition.
decreaseInvalidationListenerCount() - Method in class com.hazelcast.cache.impl.CacheContext
 
decreaseInvalidationListenerCount() - Method in class com.hazelcast.map.impl.MapContainer
 
decrement(UUID) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.TxnReservedCapacityCounter
Decrements capacity count for a transaction.
decrement(UUID) - Method in class com.hazelcast.map.impl.mapstore.writebehind.TxnReservedCapacityCounterImpl
Decrements 2 counters for supplied txnId.
decrementAndGet() - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
decrementAndGet() - Method in class com.hazelcast.client.impl.proxy.ClientPNCounterProxy
 
decrementAndGet() - Method in interface com.hazelcast.cp.IAtomicLong
Atomically decrements the current value by one.
decrementAndGet() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
decrementAndGet() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Decrements by one the current value.
decrementAndGet() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterProxy
 
decrementAndGet() - Method in class com.hazelcast.internal.jmx.AtomicLongMBean
 
decrementAndGet() - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
decrementAndGet() - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
decrementAndGetAsync() - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
decrementAndGetAsync() - Method in interface com.hazelcast.cp.IAtomicLong
Atomically decrements the current value by one.
decrementAndGetAsync() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
decrementAndGetAsync() - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
decrementAndGetAsync() - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
decrementOnlyReserved(UUID) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.TxnReservedCapacityCounter
Decrements capacity count for a transaction.
decrementOnlyReserved(UUID) - Method in class com.hazelcast.map.impl.mapstore.writebehind.TxnReservedCapacityCounterImpl
 
decrementOwnedEntryCount() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
decrementOwnedEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
decrypt(String) - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
Decrypts given encrypted variable.
deepCopy() - Method in class com.hazelcast.client.impl.protocol.ClientMessage.Frame
 
DEFAULT_ACKNOWLEDGE_TYPE - Static variable in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
DEFAULT_APPEND_REQUEST_BACKOFF_TIMEOUT_IN_MILLIS - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
Default append request backoff timeout in millis.
DEFAULT_APPEND_REQUEST_MAX_ENTRY_COUNT - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
The default maximum append request entry count.
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.CardinalityEstimatorConfig
The number of async backups per estimator
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_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 default number of backups
DEFAULT_BATCH_MAX_DELAY_MILLIS - Static variable in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
DEFAULT_BATCH_SIZE - Static variable in class com.hazelcast.config.MergePolicyConfig
Default batch size.
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_BATCH_SIZE - Static variable in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
DEFAULT_BUFFER_SIZE - Static variable in class com.hazelcast.config.QueryCacheConfig
By default, only buffer last DEFAULT_BUFFER_SIZE events fired from a partition.
DEFAULT_BUFFER_SIZE_BYTE - Static variable in class com.hazelcast.client.config.SocketOptions
default buffer size of Bytes
DEFAULT_CACHE_ENTRY_VIEW - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
DEFAULT_CACHED_DESERIALIZED_VALUES - Static variable in class com.hazelcast.config.MapConfig
We want to cache values only when an index is defined.
DEFAULT_CALL_TIMEOUT - Static variable in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Default call timeout.
DEFAULT_CAPACITY - Static variable in class com.hazelcast.config.EventJournalConfig
Default value of capacity of the event journal.
DEFAULT_CAPACITY - Static variable in class com.hazelcast.config.RingbufferConfig
Default value of capacity of the RingBuffer.
DEFAULT_CAPACITY - Static variable in class com.hazelcast.internal.util.hashslot.impl.CapacityUtil
Default capacity for a hash container.
DEFAULT_CIPHER_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Default value for "cipherAlgorithm" property.
DEFAULT_CLUSTER_NAME - Static variable in class com.hazelcast.config.Config
Default cluster name.
DEFAULT_CLUSTER_NAME - Static variable in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
DEFAULT_CLUSTER_NAME - Static variable in interface com.hazelcast.osgi.impl.HazelcastInternalOSGiService
Default cluster name to be used when grouping is not disabled with HazelcastOSGiService.HAZELCAST_OSGI_GROUPING_DISABLED.
DEFAULT_COALESCE - Static variable in class com.hazelcast.config.QueryCacheConfig
Default value of coalesce property.
DEFAULT_COMMIT_INDEX_ADVANCE_COUNT_TO_SNAPSHOT - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
The default commit index advance count on Raft log to take a snapshot.
DEFAULT_DATA_LOAD_TIMEOUT - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
Default load timeout
DEFAULT_DATA_LOAD_TIMEOUT_SECONDS - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
The default data load timeout duration for restoring CP data from disk.
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.impl.operationservice.InvocationBuilder
True that the result of an operation automatically should be deserialized to an object.
DEFAULT_DISCOVERY_PERIOD_SECONDS - Static variable in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
DEFAULT_DURABILITY - Static variable in class com.hazelcast.config.DurableExecutorConfig
Durability of Executor.
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_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_STRATEGY - Static variable in enum com.hazelcast.internal.eviction.EvictionStrategyType
Default value of EvictionStrategyType
DEFAULT_EXPIRATION_TASK_INITIAL_DELAY_SECONDS - Static variable in interface com.hazelcast.internal.nearcache.NearCache
Default expiration task initial delay time as seconds
DEFAULT_EXPIRATION_TASK_PERIOD_SECONDS - Static variable in interface com.hazelcast.internal.nearcache.NearCache
Default expiration task delay time as seconds
DEFAULT_FETCH_SIZE - Static variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
DEFAULT_FLAGS - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
DEFAULT_FORCED_EVICTION_RETRY_COUNT - Static variable in class com.hazelcast.map.impl.operation.WithForcedEviction
 
DEFAULT_GLOBAL_ORDERING_ENABLED - Static variable in class com.hazelcast.config.TopicConfig
Default global ordering configuration.
DEFAULT_GROUP_NAME - Static variable in interface com.hazelcast.cp.CPGroup
Name of the DEFAULT CP group that is used when no group name is specified while creating a CP data structure proxy.
DEFAULT_HEARTBEAT_INTERVAL_MILLIS - Static variable in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
Default value of heartbeat interval (in milliseconds).
DEFAULT_HEARTBEAT_INTERVAL_SECONDS - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
The default duration for the periodically-committed CP session heartbeats.
DEFAULT_HEARTBEAT_PAUSE_MILLIS - Static variable in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
Default duration in milliseconds corresponding to number of potentially lost/delayed heartbeats that will be accepted before considering it to be an anomaly.
DEFAULT_HEARTBEAT_TOLERANCE_MILLIS - Static variable in class com.hazelcast.config.RecentlyActiveSplitBrainProtectionConfigBuilder
Default duration of time window during which a heartbeat must have been received from a member, for it to be considered present for split brain protection (in milliseconds).
DEFAULT_ID - Static variable in interface com.hazelcast.osgi.impl.HazelcastInternalOSGiService
Default ID for HazelcastInternalOSGiService instance
DEFAULT_IDLE_MAX_PARK_NS - Static variable in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
DEFAULT_IDLE_MIN_PARK_NS - Static variable in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
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 in-memory format.
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.internal.util.collection.Int2ObjectHashMap
The default initial capacity for constructors not explicitly supplying it.
DEFAULT_INITIAL_CAPACITY - Static variable in class com.hazelcast.internal.util.collection.Long2LongHashMap
The default initial capacity for constructors not explicitly supplying it
DEFAULT_INITIAL_CAPACITY - Static variable in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
The default initial capacity for constructors not explicitly supplying it
DEFAULT_INITIAL_PUBLISHER_STATE - Static variable in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
DEFAULT_INTERVAL_MILLISECONDS - Static variable in class com.hazelcast.client.config.ClientIcmpPingConfig
Default interval between icmp ping attempts see ClientIcmpPingConfig.intervalMilliseconds
DEFAULT_INVALIDATE_ON_CHANGE - Static variable in class com.hazelcast.config.NearCacheConfig
 
DEFAULT_KEYSTORE_TYPE - Static variable in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
The default Java KeyStore type (PKCS12).
DEFAULT_LEADER_ELECTION_TIMEOUT_IN_MILLIS - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
The default leader election timeout in millis.
DEFAULT_LEADER_HEARTBEAT_PERIOD_IN_MILLIS - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
The default leader heartbeat period in millis.
DEFAULT_LOAD_FACTOR - Static variable in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
The default load factor for constructors not explicitly supplying it.
DEFAULT_LOAD_FACTOR - Static variable in class com.hazelcast.internal.util.collection.Long2LongHashMap
The default load factor for constructors not explicitly supplying it
DEFAULT_LOAD_FACTOR - Static variable in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
The default load factor for constructors not explicitly supplying it
DEFAULT_LOAD_FACTOR - Static variable in class com.hazelcast.internal.util.hashslot.impl.CapacityUtil
Default load factor.
DEFAULT_LOCAL_UPDATE_POLICY - Static variable in class com.hazelcast.config.NearCacheConfig
 
DEFAULT_LOCK_ACQUIRE_LIMIT - Static variable in class com.hazelcast.config.cp.FencedLockConfig
The default reentrant lock acquire limit of FencedLock.
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_NAME - Static variable in class com.hazelcast.internal.ascii.memcache.MemcacheCommandProcessor
 
DEFAULT_MAX_ATTEMPT - Static variable in class com.hazelcast.client.config.ClientIcmpPingConfig
Default max number of attempts ClientIcmpPingConfig.maxAttempts
DEFAULT_MAX_CONCURRENT_INVOCATIONS - Static variable in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
DEFAULT_MAX_CONCURRENT_REPLICATION_TARGETS - Static variable in class com.hazelcast.config.CRDTReplicationConfig
The default maximum number of members to which the CRDT states are replicated in a single round.
DEFAULT_MAX_ENTRY_COUNT - Static variable in class com.hazelcast.config.EvictionConfig
Default maximum entry count.
DEFAULT_MAX_ENTRY_COUNT_FOR_ON_HEAP_MAP - Static variable in class com.hazelcast.config.EvictionConfig
Default maximum entry count for Map on-heap Near Caches.
DEFAULT_MAX_IDLE - Static variable in interface com.hazelcast.map.impl.recordstore.RecordStore
Default Max Idle value of a record.
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 the maximum idle time for eviction in seconds.
DEFAULT_MAX_MISSED_LEADER_HEARTBEAT_COUNT - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
Default max number of missed heartbeats to trigger a new leader election.
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.QueueConfig
Default value for the maximum size of the Queue.
DEFAULT_MAX_SIZE_POLICY - Static variable in class com.hazelcast.config.EvictionConfig
Default Max-Size Policy.
DEFAULT_MAX_TARGET_ENDPOINTS - Static variable in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
DEFAULT_MEMORY_FORMAT - Static variable in class com.hazelcast.config.NearCacheConfig
Default value for the in-memory format.
DEFAULT_MERGE_POLICY - Static variable in class com.hazelcast.config.MergePolicyConfig
Default merge policy.
DEFAULT_MERGE_POLICY_CONFIG - Static variable in class com.hazelcast.config.CardinalityEstimatorConfig
The default merge policy used for cardinality estimators
DEFAULT_METADATA_POLICY - Static variable in class com.hazelcast.config.MapConfig
Default metadata policy
DEFAULT_METADATA_SPACE_PERCENTAGE - Static variable in class com.hazelcast.config.NativeMemoryConfig
Default metadata space percentage
DEFAULT_METRICS_COLLECTION_SECONDS - Static variable in class com.hazelcast.config.MetricsConfig
Default collection interval for metrics
DEFAULT_METRICS_RETENTION_SECONDS - Static variable in class com.hazelcast.config.MetricsConfig
Default retention period for metrics.
DEFAULT_MIN_BLOCK_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
Default minimum block size in bytes
DEFAULT_MIN_STD_DEVIATION - Static variable in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
Default minimum standard deviation (in milliseconds) to use for the normal distribution used when calculating phi.
DEFAULT_MISSING_CP_MEMBER_AUTO_REMOVAL_SECONDS - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
The default duration to wait before automatically removing a missing CP member from CP Subsystem.
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 in bytes
DEFAULT_PARALLELISM - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
Default level of parallelism in Hot Restart Persistence.
DEFAULT_PARTITION_COUNT - Static variable in class com.hazelcast.monitor.impl.MemberPartitionStateImpl
 
DEFAULT_PERSIST_WAN_REPLICATED_DATA - Static variable in class com.hazelcast.config.WanConsumerConfig
 
DEFAULT_PHI_THRESHOLD - Static variable in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
Default threshold for suspicion (φ) level.
DEFAULT_POLLING_INTERVAL - Static variable in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Default interval (in seconds) for polling for changes in the KeyStore: 0 (polling disabled).
DEFAULT_POLLING_INTERVAL - Static variable in class com.hazelcast.config.VaultSecureStoreConfig
Default interval (in seconds) for polling for changes to the encryption key: 0 (polling disabled).
DEFAULT_POOL_SIZE - Static variable in class com.hazelcast.config.DurableExecutorConfig
The number of executor threads per Member for the Executor based on this configuration.
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_PORT - Static variable in class com.hazelcast.config.ServerSocketEndpointConfig
Default value of port number.
DEFAULT_PREFETCH_COUNT - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
DEFAULT_PREFETCH_VALIDITY_MILLIS - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
DEFAULT_QUEUE_CAPACITY - Static variable in class com.hazelcast.config.ExecutorConfig
Capacity of queue.
DEFAULT_QUEUE_CAPACITY - Static variable in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
DEFAULT_QUEUE_FULL_BEHAVIOUR - Static variable in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
DEFAULT_RAFT_GROUP_QUERY_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
DEFAULT_RAFT_GROUP_REPLICATE_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
DEFAULT_READ_BATCH_SIZE - Static variable in class com.hazelcast.client.config.ClientReliableTopicConfig
The default read batch size.
DEFAULT_READ_BATCH_SIZE - Static variable in class com.hazelcast.config.ReliableTopicConfig
The default read batch size.
DEFAULT_REALM - Static variable in class com.hazelcast.config.security.RealmConfig
Default security realm instance.
DEFAULT_REPLICA_COUNT - Static variable in class com.hazelcast.config.PNCounterConfig
The default number of replicas on which state for this CRDT is kept
DEFAULT_REPLICA_INDEX - Static variable in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Default replica index.
DEFAULT_REPLICATION_PERIOD_MILLIS - Static variable in class com.hazelcast.config.CRDTReplicationConfig
The default period between two CRDT replication rounds.
DEFAULT_RESPONSE_TIMEOUT_MILLIS - Static variable in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
DEFAULT_RING_BUFFER_CAPACITY - Static variable in class com.hazelcast.config.DurableExecutorConfig
Capacity of RingBuffer (per partition).
DEFAULT_SAMPLE_COUNT - Static variable in interface com.hazelcast.map.impl.eviction.Evictor
 
DEFAULT_SAMPLE_SIZE - Static variable in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
Default number of samples to use for calculation of mean and standard deviation of inter-arrival times.
DEFAULT_SECRET_KEY_FACTORY_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Default value for "secretKeyFactoryAlgorithm" property.
DEFAULT_SEMAPHORE_JDK_COMPATIBILITY - Static variable in class com.hazelcast.config.cp.SemaphoreConfig
The default value for the JDK compatibility mode of CP ISemaphore
DEFAULT_SERIALIZE_KEYS - Static variable in class com.hazelcast.config.NearCacheConfig
Do not serialize by default
DEFAULT_SESSION_TTL_SECONDS - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
The default value for a CP session to be kept alive after the last heartbeat it has received.
DEFAULT_SNAPSHOT_ENABLED - Static variable in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
DEFAULT_SOCKET_CONNECT_TIMEOUT_SECONDS - Static variable in class com.hazelcast.config.EndpointConfig
DEFAULT_SOCKET_LINGER_SECONDS - Static variable in class com.hazelcast.config.EndpointConfig
DEFAULT_SOCKET_RECEIVE_BUFFER_SIZE_KB - Static variable in class com.hazelcast.config.EndpointConfig
DEFAULT_SOCKET_SEND_BUFFER_SIZE_KB - Static variable in class com.hazelcast.config.EndpointConfig
DEFAULT_STATISTICS_ENABLED - Static variable in class com.hazelcast.config.PNCounterConfig
Default value for statistics enabled.
DEFAULT_STATISTICS_ENABLED - Static variable in class com.hazelcast.config.ReliableTopicConfig
Default value for statistics enabled.
DEFAULT_STORE_INITIAL_DELAY_SECONDS - Static variable in class com.hazelcast.config.NearCachePreloaderConfig
Default initial delay for the Near Cache key storage.
DEFAULT_STORE_INTERVAL_SECONDS - Static variable in class com.hazelcast.config.NearCachePreloaderConfig
Default interval for the Near Cache key storage (in seconds).
DEFAULT_SYMMETRIC_ALGORITHM - Static variable in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
Default symmetric encryption algorithm.
DEFAULT_SYMMETRIC_ALGORITHM - Static variable in class com.hazelcast.config.SymmetricEncryptionConfig
Default symmetric encryption algorithm
DEFAULT_SYMMETRIC_PASSWORD - Static variable in class com.hazelcast.config.SymmetricEncryptionConfig
Default symmetric encryption password
DEFAULT_SYMMETRIC_SALT - Static variable in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
Default symmetric encryption salt.
DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.CardinalityEstimatorConfig
The number of sync backups per estimator
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_TARGET_ENDPOINTS - Static variable in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
DEFAULT_TIMEOUT_MILLIS - Static variable in class com.hazelcast.transaction.TransactionOptions
2 minutes as default timeout value
DEFAULT_TIMEOUT_MILLISECONDS - Static variable in class com.hazelcast.client.config.ClientIcmpPingConfig
Default timeout for icmp detection in millis see ClientIcmpPingConfig.timeoutMilliseconds
DEFAULT_TOPIC_OVERLOAD_POLICY - Static variable in class com.hazelcast.client.config.ClientReliableTopicConfig
The default slow consumer policy.
DEFAULT_TOPIC_OVERLOAD_POLICY - Static variable in class com.hazelcast.config.ReliableTopicConfig
The default slow consumer policy.
DEFAULT_TRY_COUNT - Static variable in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Default try count.
DEFAULT_TRY_PAUSE_MILLIS - Static variable in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Default try pause in milliseconds.
DEFAULT_TTL - Static variable in class com.hazelcast.client.config.ClientIcmpPingConfig
Default ttl for icmp packages ClientIcmpPingConfig.ttl.
DEFAULT_TTL - Static variable in interface com.hazelcast.map.impl.recordstore.RecordStore
Default TTL value of a record.
DEFAULT_TTL_SECONDS - Static variable in class com.hazelcast.config.EventJournalConfig
Default value for the time to live property.
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 the 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 - Static variable in class com.hazelcast.config.IndexConfig
Default index type.
DEFAULT_UNCOMMITTED_ENTRY_COUNT_TO_REJECT_NEW_APPENDS - Static variable in class com.hazelcast.config.cp.RaftAlgorithmConfig
The default maximum allowed uncommitted entry count.
DEFAULT_USE_ENDPOINT_PRIVATE_ADDRESS - Static variable in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
DEFAULT_VALIDATION_TIMEOUT - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
Default validation timeout
DEFAULT_VALUE_COLLECTION_TYPE - Static variable in class com.hazelcast.config.MultiMapConfig
Default value collection type of this MultiMap.
DEFAULT_WRITE_BATCH_SIZE - Static variable in class com.hazelcast.config.MapStoreConfig
Default batch size for writing
DEFAULT_WRITE_COALESCING - Static variable in class com.hazelcast.config.MapStoreConfig
Default write coalescing behavior
DEFAULT_WRITE_DELAY_SECONDS - Static variable in class com.hazelcast.config.MapStoreConfig
Default delay seconds for writing
DefaultAccumulatorInfoSupplier - Class in com.hazelcast.map.impl.querycache.accumulator
Default implementation of AccumulatorInfoSupplier.
DefaultAccumulatorInfoSupplier() - Constructor for class com.hazelcast.map.impl.querycache.accumulator.DefaultAccumulatorInfoSupplier
 
DefaultAddressProvider - Class in com.hazelcast.client.impl.spi.impl
Default address provider of Hazelcast.
DefaultAddressProvider(ClientNetworkConfig) - Constructor for class com.hazelcast.client.impl.spi.impl.DefaultAddressProvider
 
DefaultAggregateEndpointManager - Class in com.hazelcast.internal.nio
 
DefaultAggregateEndpointManager(ConcurrentMap<EndpointQualifier, EndpointManager<TcpIpConnection>>) - Constructor for class com.hazelcast.internal.nio.DefaultAggregateEndpointManager
 
DefaultArgumentParser - Class in com.hazelcast.query.impl
ArgumentParser that's used by default.
DefaultArgumentParser() - Constructor for class com.hazelcast.query.impl.DefaultArgumentParser
 
DefaultAuthenticationConfig - Class in com.hazelcast.config.security
Default AuthenticationConfig implementation which just references the DefaultLoginModule.
DefaultCacheEntryView - Class in com.hazelcast.cache.impl.merge.entry
Default heap based implementation of CacheEntryView.
DefaultCacheEntryView() - Constructor for class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
 
DefaultCacheEntryView(Data, Data, long, long, long, long, Data) - Constructor for class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
 
DefaultChannelInitializerProvider - Class in com.hazelcast.internal.nio.tcp
 
DefaultChannelInitializerProvider(IOService, Config) - Constructor for class com.hazelcast.internal.nio.tcp.DefaultChannelInitializerProvider
 
DefaultClientConnectionManagerFactory - Class in com.hazelcast.client.impl.clientside
 
DefaultClientConnectionManagerFactory() - Constructor for class com.hazelcast.client.impl.clientside.DefaultClientConnectionManagerFactory
 
DefaultClientConnectionStrategy - Class in com.hazelcast.client.impl.connection.nio
Default client connection strategy supporting async client start, reconnection modes and disabling reconnection.
DefaultClientConnectionStrategy() - Constructor for class com.hazelcast.client.impl.connection.nio.DefaultClientConnectionStrategy
 
DefaultClientExtension - Class in com.hazelcast.client.impl.clientside
 
DefaultClientExtension() - Constructor for class com.hazelcast.client.impl.clientside.DefaultClientExtension
 
DefaultCyclicBuffer<E extends Sequenced> - Class in com.hazelcast.map.impl.querycache.accumulator
Default implementation of CyclicBuffer interface.
DefaultCyclicBuffer(int) - Constructor for class com.hazelcast.map.impl.querycache.accumulator.DefaultCyclicBuffer
 
DefaultDiscoveryService - Class in com.hazelcast.spi.discovery.impl
 
DefaultDiscoveryService(DiscoveryServiceSettings) - Constructor for class com.hazelcast.spi.discovery.impl.DefaultDiscoveryService
 
DefaultDiscoveryServiceProvider - Class in com.hazelcast.spi.discovery.impl
 
DefaultDiscoveryServiceProvider() - Constructor for class com.hazelcast.spi.discovery.impl.DefaultDiscoveryServiceProvider
 
DefaultEntryEventFilteringStrategy - Class in com.hazelcast.map.impl.event
This entry event filtering strategy models the default backwards compatible Hazelcast behaviour.
DefaultEntryEventFilteringStrategy(InternalSerializationService, MapServiceContext) - Constructor for class com.hazelcast.map.impl.event.DefaultEntryEventFilteringStrategy
 
defaultExecutor() - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
defaultExpiryPolicy - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
DefaultGarbageCollectorStats - Class in com.hazelcast.internal.memory
Default implementation of GarbageCollectorStats.
DefaultGarbageCollectorStats() - Constructor for class com.hazelcast.internal.memory.DefaultGarbageCollectorStats
 
DefaultIndexProvider - Class in com.hazelcast.query.impl
Provides on-heap indexes.
DefaultIndexProvider() - Constructor for class com.hazelcast.query.impl.DefaultIndexProvider
 
DefaultMapAggregateMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.map
 
DefaultMapAggregateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.DefaultMapAggregateMessageTask
 
DefaultMapOperationProvider - Class in com.hazelcast.map.impl.operation
Creates map operations.
DefaultMapOperationProvider() - Constructor for class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
 
DefaultMapProjectMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.map
 
DefaultMapProjectMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.DefaultMapProjectMessageTask
 
DefaultMapQueryMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.map
 
DefaultMapQueryMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.DefaultMapQueryMessageTask
 
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.internal.memory
Default implementation of MemoryStats.
DefaultMemoryStats() - Constructor for class com.hazelcast.internal.memory.DefaultMemoryStats
 
DefaultMessageTaskFactoryProvider - Class in com.hazelcast.client.impl.protocol
DO NOT EDIT THIS FILE.
DefaultMessageTaskFactoryProvider(NodeEngine) - Constructor for class com.hazelcast.client.impl.protocol.DefaultMessageTaskFactoryProvider
 
DefaultNearCache<K,V> - Class in com.hazelcast.internal.nearcache.impl
 
DefaultNearCache(String, NearCacheConfig, SerializationService, TaskScheduler, ClassLoader, HazelcastProperties) - Constructor for class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
DefaultNearCache(String, NearCacheConfig, NearCacheRecordStore<K, V>, SerializationService, TaskScheduler, ClassLoader, HazelcastProperties) - Constructor for class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
DefaultNearCacheManager - Class in com.hazelcast.internal.nearcache.impl
 
DefaultNearCacheManager(SerializationService, TaskScheduler, ClassLoader, HazelcastProperties) - Constructor for class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
 
DefaultNodeContext - Class in com.hazelcast.instance.impl
 
DefaultNodeContext() - Constructor for class com.hazelcast.instance.impl.DefaultNodeContext
 
DefaultNodeExtension - Class in com.hazelcast.instance.impl
 
DefaultNodeExtension(Node) - Constructor for class com.hazelcast.instance.impl.DefaultNodeExtension
 
DefaultOperationProvider - Class in com.hazelcast.cache.impl
Provide operations other then InMemoryFormat.NATIVE
DefaultOperationProvider(String) - Constructor for class com.hazelcast.cache.impl.DefaultOperationProvider
 
DefaultOutOfMemoryHandler - Class in com.hazelcast.instance.impl
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.impl.DefaultOutOfMemoryHandler
 
DefaultOutOfMemoryHandler(double) - Constructor for class com.hazelcast.instance.impl.DefaultOutOfMemoryHandler
 
DefaultOutOfMemoryHandler(double, MemoryInfoAccessor) - Constructor for class com.hazelcast.instance.impl.DefaultOutOfMemoryHandler
 
DefaultPartitioningStrategy - Class in com.hazelcast.partition.strategy
A PartitioningStrategy that checks if the key implements PartitionAware.
DefaultPartitioningStrategy() - Constructor for class com.hazelcast.partition.strategy.DefaultPartitioningStrategy
 
DefaultPartitionSequencer - Class in com.hazelcast.map.impl.querycache.event.sequence
Default implementation of PartitionSequencer.
DefaultPartitionSequencer() - Constructor for class com.hazelcast.map.impl.querycache.event.sequence.DefaultPartitionSequencer
 
DefaultPortableReader - Class in com.hazelcast.internal.serialization.impl
Can't be accessed concurrently.
DefaultPortableWriter - Class in com.hazelcast.internal.serialization.impl
 
DefaultPublisherContext - Class in com.hazelcast.map.impl.querycache.publisher
Default implementation of PublisherContext.
DefaultPublisherContext(QueryCacheContext, NodeEngine, Function<String, UUID>) - Constructor for class com.hazelcast.map.impl.querycache.publisher.DefaultPublisherContext
 
DefaultQueryCacheEventData - Class in com.hazelcast.map.impl.querycache.event
Default implementation of QueryCacheEventData which is sent to subscriber.
DefaultQueryCacheEventData() - Constructor for class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
DefaultQueryCacheEventData(DefaultQueryCacheEventData) - Constructor for class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
DefaultRaftReplicateOp - Class in com.hazelcast.cp.internal.operation
The operation used by RaftInvocationManager to replicate a given RaftOp to leader of the target Raft group.
DefaultRaftReplicateOp() - Constructor for class com.hazelcast.cp.internal.operation.DefaultRaftReplicateOp
 
DefaultRaftReplicateOp(CPGroupId, RaftOp) - Constructor for class com.hazelcast.cp.internal.operation.DefaultRaftReplicateOp
 
DefaultRecordStore - Class in com.hazelcast.map.impl.recordstore
Default implementation of record-store.
DefaultRecordStore(MapContainer, int, MapKeyLoader, ILogger) - Constructor for class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
DefaultSerializationServiceBuilder - Class in com.hazelcast.internal.serialization.impl
 
DefaultSerializationServiceBuilder() - Constructor for class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
DefaultSubscriberSequencerProvider - Class in com.hazelcast.map.impl.querycache.event.sequence
This class provides on-demand PartitionSequencer implementations for subscriber side.
DefaultSubscriberSequencerProvider() - Constructor for class com.hazelcast.map.impl.querycache.event.sequence.DefaultSubscriberSequencerProvider
 
DefaultValueCollector - Class in com.hazelcast.query.impl
 
DefaultValueCollector() - Constructor for class com.hazelcast.query.impl.DefaultValueCollector
 
DeferredValue<V> - Class in com.hazelcast.cache.impl
Thread-safe holder of value and/or its serialized form.
define(String, byte[]) - Method in class com.hazelcast.internal.usercodedeployment.impl.ClassSource
 
defineClass(String, byte[]) - Method in class com.hazelcast.internal.usercodedeployment.UserCodeDeploymentService
 
defineClassFromClient(String, byte[]) - Method in class com.hazelcast.internal.usercodedeployment.impl.ClassLocator
 
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
General contract for an entry to be stored into MapStore when MapStoreConfig.writeDelaySeconds is greater than 0.
DelayQueueStreamSerializer<E extends Delayed> - Class in com.hazelcast.internal.serialization.impl
The DelayQueue serializer
DelayQueueStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.DelayQueueStreamSerializer
 
delaySeconds - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateCodec.RequestParameters
The minimum number of delay seconds which an event waits in the buffer of node.
delaySeconds - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateWithValueCodec.RequestParameters
The minimum number of delay seconds which an event waits in the buffer of node.
DelegateAndSkipOnConcurrentExecutionDecorator - Class in com.hazelcast.spi.impl.executionservice.impl
Decorator to delegate task to an executor and prevent concurrent task execution.
DelegateAndSkipOnConcurrentExecutionDecorator(Runnable, Executor) - Constructor for class com.hazelcast.spi.impl.executionservice.impl.DelegateAndSkipOnConcurrentExecutionDecorator
 
DelegatingCompletableFuture<V> - Class in com.hazelcast.spi.impl
A InternalCompletableFuture implementation that delegates the real logic to an underlying InternalCompletableFuture and decorates it with additional behavior: change the returned value by setting the result caching the deserialized content so that a deserialization only happens once.
DelegatingCompletableFuture(SerializationService, CompletableFuture) - Constructor for class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
DelegatingCompletableFuture(SerializationService, CompletableFuture, V) - Constructor for class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
DelegatingScheduledFutureStripper<V> - Class in com.hazelcast.scheduledexecutor.impl
Simple adapter that unwraps the Future delegation done in DelegatingCallableTaskDecorator for single-run Callable tasks.
DelegatingScheduledFutureStripper(ScheduledFuture<V>) - Constructor for class com.hazelcast.scheduledexecutor.impl.DelegatingScheduledFutureStripper
 
DelegatingTaskScheduler - Class in com.hazelcast.spi.impl.executionservice.impl
 
DelegatingTaskScheduler(ScheduledExecutorService, ExecutorService) - Constructor for class com.hazelcast.spi.impl.executionservice.impl.DelegatingTaskScheduler
 
DelegatingWanReplicationScheme - Class in com.hazelcast.wan.impl
WAN replication scheme implementation delegating to multiple WAN replication publisher implementations.
DelegatingWanReplicationScheme(String, ConcurrentMap<String, WanReplicationPublisher>) - Constructor for class com.hazelcast.wan.impl.DelegatingWanReplicationScheme
 
delete(Object) - Method in class com.hazelcast.cache.impl.LatencyTrackingCacheWriter
 
delete(Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
delete(Object) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
delete(Object) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
delete(Long) - Method in class com.hazelcast.collection.impl.queue.LatencyTrackingQueueStore
 
delete(Long) - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
 
delete(Long) - Method in interface com.hazelcast.collection.QueueStore
Deletes the entry with a given key from the store.
delete(K) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
delete(K) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
delete(K) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
delete(K) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
delete(K) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
delete(String, String) - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
delete(String, String) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
delete(File) - Static method in class com.hazelcast.internal.nio.IOUtil
Ensures that the file described by the supplied parameter does not exist after the method returns.
delete(Object) - Method in interface com.hazelcast.map.BaseMap
Removes the mapping for a key from this map if it is present.
delete(Object) - Method in interface com.hazelcast.map.IMap
Removes the mapping for the key from this map if it is present.
delete(K) - Method in class com.hazelcast.map.impl.LatencyTrackingMapStore
 
DELETE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
delete(Object) - Method in class com.hazelcast.map.impl.MapStoreWrapper
 
delete(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
delete(Object, EntryEventType) - Method in interface com.hazelcast.map.impl.querycache.subscriber.InternalQueryCache
 
delete(Object, EntryEventType) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
delete(Data, CallerProvenance) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
delete(Data, CallerProvenance) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
delete(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
delete(K) - Method in interface com.hazelcast.map.MapStore
Deletes the entry with a given key from the store.
delete(K) - Method in class com.hazelcast.map.MapStoreAdapter
Deletes the entry with a given key from the store.
delete(Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
DELETE - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
delete(Object) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
delete(Object) - Method in interface com.hazelcast.multimap.MultiMap
Deletes all the entries with the given key.
delete(Object) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.delete(Object).
DELETE_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
deleteAll(Collection<?>) - Method in class com.hazelcast.cache.impl.LatencyTrackingCacheWriter
 
deleteAll(Collection<Long>) - Method in class com.hazelcast.collection.impl.queue.LatencyTrackingQueueStore
 
deleteAll(Collection<Long>) - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
 
deleteAll(Collection<Long>) - Method in interface com.hazelcast.collection.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<K>) - Method in class com.hazelcast.map.impl.LatencyTrackingMapStore
 
deleteAll(Collection) - Method in class com.hazelcast.map.impl.MapStoreWrapper
 
deleteAll(Collection<K>) - Method in interface com.hazelcast.map.MapStore
Deletes multiple entries from the store.
deleteAll(Collection<K>) - Method in class com.hazelcast.map.MapStoreAdapter
Deletes multiple entries from the store.
deleteAllCacheEntry(Set<Data>) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
deleteAsync(K) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
deleteAsync(K) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
deleteAsync(K) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
deleteAsync(K) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
deleteAsync(K) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
DeleteBackupOperation - Class in com.hazelcast.multimap.impl.operations
 
DeleteBackupOperation() - Constructor for class com.hazelcast.multimap.impl.operations.DeleteBackupOperation
 
DeleteBackupOperation(String, Data) - Constructor for class com.hazelcast.multimap.impl.operations.DeleteBackupOperation
 
deleteCache(String, UUID, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
deleteCache(String, UUID, boolean) - Method in interface com.hazelcast.cache.impl.ICacheService
 
deleteCacheConfig(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
deleteCacheConfig(String) - Method in interface com.hazelcast.cache.impl.ICacheService
 
deleteCacheEntry(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
deleteCacheEntry(Data, CallerProvenance) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
deleteCacheResources(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
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
 
deleteEntriesFrom(long) - Method in class com.hazelcast.cp.internal.raft.impl.log.RaftLog
Deletes all log entries with index >= entryIndex.
deleteEntriesFrom(long) - Method in class com.hazelcast.cp.internal.raft.impl.persistence.NopRaftStateStore
 
deleteEntriesFrom(long) - Method in interface com.hazelcast.cp.internal.raft.impl.persistence.RaftStateStore
Rolls back the log by deleting all entries starting with the given index.
deleteInternal(Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
deleteInternal(Object) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
deleteInternal(Object) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
deleteInternal(Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
DeleteOperation - Class in com.hazelcast.map.impl.operation
 
DeleteOperation(String, Data, boolean) - Constructor for class com.hazelcast.map.impl.operation.DeleteOperation
 
DeleteOperation() - Constructor for class com.hazelcast.map.impl.operation.DeleteOperation
 
DeleteOperation - Class in com.hazelcast.multimap.impl.operations
 
DeleteOperation() - Constructor for class com.hazelcast.multimap.impl.operations.DeleteOperation
 
DeleteOperation(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.DeleteOperation
 
deleteQuietly(File) - Static method in class com.hazelcast.internal.nio.IOUtil
Ensures that the file described by the supplied parameter does not exist after the method returns.
deleteRecord(Data, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
deleteRecord(Data, int, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
deleteRecord(Data, int, UUID, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
deleteRecordStore(String, boolean) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
 
delta - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongAddAndGetCodec.RequestParameters
The value to add to the current value
delta - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndAddCodec.RequestParameters
The value to add to the current value
delta - Variable in class com.hazelcast.client.impl.protocol.codec.PNCounterAddCodec.RequestParameters
the delta to add to the counter value, can be negative
delta - Variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterAddAndGetCodec.RequestParameters
the value to add to the current value
delta - Variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndAddCodec.RequestParameters
the value to add to the current value
DenseHyperLogLogEncoder - Class in com.hazelcast.cardinality.impl.hyperloglog.impl
1.
DenseHyperLogLogEncoder() - Constructor for class com.hazelcast.cardinality.impl.hyperloglog.impl.DenseHyperLogLogEncoder
 
DenseHyperLogLogEncoder(int) - Constructor for class com.hazelcast.cardinality.impl.hyperloglog.impl.DenseHyperLogLogEncoder
 
DenseHyperLogLogEncoder(int, byte[]) - Constructor for class com.hazelcast.cardinality.impl.hyperloglog.impl.DenseHyperLogLogEncoder
 
DenyAllPermissionCollection - Class in com.hazelcast.security.permission
 
DenyAllPermissionCollection() - Constructor for class com.hazelcast.security.permission.DenyAllPermissionCollection
 
deploy(HazelcastClientInstanceImpl, Connection) - Method in class com.hazelcast.client.impl.spi.impl.ClientUserCodeDeploymentService
 
DEPLOY_CLASSES_OP - Static variable in class com.hazelcast.internal.usercodedeployment.impl.UserCodeDeploymentSerializerHook
 
DeployClassesMessageTask - Class in com.hazelcast.client.impl.protocol.task
Message task handling user code deployment from client to cluster
DeployClassesMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.DeployClassesMessageTask
 
DeployClassesOperation - Class in com.hazelcast.internal.usercodedeployment.impl.operation
Operation to distribute class definitions uploaded from client to cluster
DeployClassesOperation(Collection<Map.Entry<String, byte[]>>) - Constructor for class com.hazelcast.internal.usercodedeployment.impl.operation.DeployClassesOperation
 
DeployClassesOperation() - Constructor for class com.hazelcast.internal.usercodedeployment.impl.operation.DeployClassesOperation
 
depth() - Method in class com.hazelcast.json.internal.JsonPattern
Returns the depth of this pattern.
deregister(Operation) - Method in class com.hazelcast.internal.metrics.impl.LiveOperationRegistry
 
deregister(String) - Method in class com.hazelcast.map.impl.InterceptorRegistry
De-registers MapInterceptor for the supplied `id`, if there is any.
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.impl.eventservice.EventService
Deregisters all listeners belonging to the given service and topic.
deregisterAllListeners(String, String) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
deregisterBackupListener(UUID) - Method in interface com.hazelcast.client.impl.ClientEngine
 
deregisterBackupListener(UUID) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
deregisterBackupListener(UUID) - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
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.impl.OutOfMemoryErrorDispatcher
 
deregisterCompletionLatch(Integer) - Method in class com.hazelcast.cache.impl.AbstractCacheSyncListenerCompleter
 
deregisterDynamicMetricsProvider(DynamicMetricsProvider) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
 
deregisterDynamicMetricsProvider(DynamicMetricsProvider) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
Deregisters the given dynamic metrics provider.
deregisterHandler(String) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingTask
 
deregisterListener(String, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
deregisterListener(String, UUID) - Method in interface com.hazelcast.cache.impl.ICacheService
 
deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.AbstractRemoveListenerMessageTask
 
deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
 
deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
 
deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
 
deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveListenerMessageTask
 
deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveEntryListenerMessageTask
 
deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemovePartitionLostListenerMessageTask
 
deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
 
deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
 
deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
 
deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
 
deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
 
deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveListenerMessageTask
 
deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicRemoveMessageListenerMessageTask
 
deregisterListener(UUID) - Method in interface com.hazelcast.client.impl.spi.ClientListenerService
 
deregisterListener(UUID) - Method in class com.hazelcast.client.impl.spi.ClientProxy
 
deregisterListener(UUID) - Method in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
deregisterListener(String, String, Object) - Method in interface com.hazelcast.spi.impl.eventservice.EventService
Deregisters a listener with the given registration ID.
deregisterListener(String, String, Object) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
deregisterPartitionListener(ClientEndpoint) - Method in class com.hazelcast.client.impl.ClientPartitionListenerService
 
deregisterRepairingHandler(String) - Method in class com.hazelcast.map.impl.nearcache.MapNearCacheManager
 
deregisterServer(HazelcastInstance) - Static method in class com.hazelcast.instance.impl.OutOfMemoryErrorDispatcher
 
DEREGISTRATION - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
DeregistrationOperation - Class in com.hazelcast.spi.impl.eventservice.impl.operations
 
DeregistrationOperation() - Constructor for class com.hazelcast.spi.impl.eventservice.impl.operations.DeregistrationOperation
 
DeregistrationOperation(String, UUID, int) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.operations.DeregistrationOperation
 
DeregistrationOperationSupplier - Class in com.hazelcast.spi.impl.eventservice.impl.operations
Supplier that creates DeregistrationOperations for a listener registration.
DeregistrationOperationSupplier(Registration, ClusterService) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.operations.DeregistrationOperationSupplier
 
descendingKeys() - Method in class com.hazelcast.internal.util.ItemCounter
Returns a List of keys in descending value order.
describeFlags(char) - Method in enum com.hazelcast.internal.nio.Packet.Type
 
DESERIALIZING_ENTRY - Static variable in class com.hazelcast.internal.journal.EventJournalDataSerializerHook
 
DeserializingCompletableFuture<V> - Class in com.hazelcast.spi.impl
Decorates InternalCompletableFuture to supply: optional value deserialization custom default async executor
DeserializingCompletableFuture() - Constructor for class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
DeserializingCompletableFuture(Executor) - Constructor for class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
DeserializingCompletableFuture(SerializationService, boolean) - Constructor for class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
DeserializingCompletableFuture(SerializationService, Executor, boolean) - Constructor for class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
DeserializingEntry<K,V> - Class in com.hazelcast.internal.journal
 
DeserializingEntry(Data, Data) - Constructor for class com.hazelcast.internal.journal.DeserializingEntry
 
DeserializingEventJournalCacheEvent<K,V> - Class in com.hazelcast.cache.impl.journal
 
DeserializingEventJournalCacheEvent() - Constructor for class com.hazelcast.cache.impl.journal.DeserializingEventJournalCacheEvent
 
DeserializingEventJournalCacheEvent(SerializationService, InternalEventJournalCacheEvent) - Constructor for class com.hazelcast.cache.impl.journal.DeserializingEventJournalCacheEvent
 
DeserializingEventJournalMapEvent<K,V> - Class in com.hazelcast.map.impl.journal
 
DeserializingEventJournalMapEvent() - Constructor for class com.hazelcast.map.impl.journal.DeserializingEventJournalMapEvent
 
DeserializingEventJournalMapEvent(SerializationService, InternalEventJournalMapEvent) - Constructor for class com.hazelcast.map.impl.journal.DeserializingEventJournalMapEvent
 
destroy() - Method in interface com.hazelcast.cache.HazelcastCacheManager
Destroys the 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
Destroys all managed caches.
destroy(String, UUID) - Method in class com.hazelcast.cache.impl.CacheEventHandler
 
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(ObjectNamespace, int) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
 
destroy(Cache) - Method in class com.hazelcast.cache.impl.tenantcontrol.CacheDestroyEventContext
 
destroy() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
destroy() - Method in class com.hazelcast.client.impl.clientside.CandidateClusterContext
 
destroy() - Method in class com.hazelcast.client.impl.querycache.ClientQueryCacheContext
 
destroy() - Method in class com.hazelcast.client.impl.spi.ClientProxy
 
destroy() - Method in class com.hazelcast.client.impl.spi.ProxyManager
 
destroy() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
destroy() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
 
destroy() - Method in class com.hazelcast.config.security.StaticCredentialsFactory
 
destroy() - Method in interface com.hazelcast.core.DistributedObject
Destroys this object cluster-wide.
destroy() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
destroy() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
destroy() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.proxy.CountDownLatchProxy
 
destroy() - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
destroy() - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.FencedLockProxy
 
destroy() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionAwareSemaphoreProxy
 
destroy() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionlessSemaphoreProxy
 
destroy() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
destroy(CPGroupId) - Method in class com.hazelcast.cp.internal.RaftInvocationManager
 
destroy() - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
destroy() - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
destroy() - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
destroy() - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
destroy() - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
destroy() - Method in class com.hazelcast.internal.jmx.ManagementService
 
destroy(ObjectNamespace, int) - Method in interface com.hazelcast.internal.journal.EventJournal
Destroys the event journal for the given object and partition ID.
destroy() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
destroy(String, UUID) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.BatchInvalidator
 
destroy(String, UUID) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
Removes supplied data structures invalidation queues and flushes their content.
destroy() - Method in class com.hazelcast.internal.nearcache.impl.preloader.NearCachePreloader
 
destroy() - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
destroy() - Method in class com.hazelcast.internal.nearcache.impl.store.BaseHeapNearCacheRecordStore
 
destroy() - Method in interface com.hazelcast.internal.nearcache.NearCache
Clears the record store and destroys it.
destroy() - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
Clears the record store and destroys it.
destroy() - Method in class com.hazelcast.internal.networking.ServerSocketRegistry
 
destroy() - Method in class com.hazelcast.internal.serialization.impl.ArrayStreamSerializer
 
destroy() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.TheByteArraySerializer
 
destroy(ObjectNamespace, int) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
 
destroy() - Method in class com.hazelcast.map.impl.MapStoreWrapper
 
destroy() - Method in class com.hazelcast.map.impl.querycache.NodeQueryCacheContext
 
destroy() - Method in interface com.hazelcast.map.impl.querycache.QueryCacheContext
Destroys everything in this context.
destroy() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
destroy() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
destroy() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
destroy(boolean) - Method in interface com.hazelcast.map.impl.recordstore.Storage
 
destroy(boolean) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
destroy() - Method in interface com.hazelcast.map.MapLoaderLifecycleSupport
Hazelcast will call this method before shutting down.
destroy() - Method in interface com.hazelcast.map.QueryCache
Destroys this cache.
destroy() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
destroy() - Method in interface com.hazelcast.nio.serialization.Serializer
Called when instance is shutting down.
destroy() - Method in class com.hazelcast.query.impl.AbstractIndex
 
destroy() - Method in class com.hazelcast.query.impl.BaseIndexStore
 
destroy() - Method in interface com.hazelcast.query.impl.Index
Releases all resources hold by this index, e.g.
destroy() - Method in interface com.hazelcast.query.impl.IndexStore
Destroys this index by releasing all its resources.
destroy(String) - Method in class com.hazelcast.replicatedmap.impl.PartitionContainer
 
destroy() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
destroy() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
destroy() - Method in class com.hazelcast.scheduledexecutor.impl.AbstractScheduledExecutorContainerHolder
 
destroy() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
destroy() - Method in interface com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainerHolder
 
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
Destroys SecurityContext and all security elements.
destroy() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
 
destroy() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
The stop method is used to stop internal services, sockets or to destroy any kind of internal state.
destroy() - Method in class com.hazelcast.spi.discovery.impl.DefaultDiscoveryService
 
destroy() - Method in class com.hazelcast.spi.discovery.impl.PredefinedDiscoveryService
 
destroy() - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryService
The start method is called on system startup to implement simple lifecycle management.
destroy() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
 
destroy() - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
destroy() - Method in class com.hazelcast.spi.impl.merge.AbstractContainerCollector
Destroys all collected containers.
destroy(C) - Method in class com.hazelcast.spi.impl.merge.AbstractContainerCollector
Destroys the owned data in the container.
destroy(T) - Method in interface com.hazelcast.spi.tenantcontrol.DestroyEventContext
Called to decouple Hazelcast object from the tenant
DESTROY_CACHE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
DESTROY_QUERY_CACHE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
DESTROY_RAFT_GROUP_COMMAND - Static variable in class com.hazelcast.cp.internal.raft.impl.RaftDataSerializerHook
 
DESTROY_RAFT_GROUP_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
DESTROY_RAFT_NODES_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
DESTROY_RAFT_OBJECT_OP - Static variable in class com.hazelcast.cp.internal.datastructures.RaftDataServiceDataSerializerHook
 
destroyAllNearCaches() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
 
destroyAllNearCaches() - Method in interface com.hazelcast.internal.nearcache.NearCacheManager
Destroys all defined NearCache instances.
destroyAllQueryCaches(String) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheEndToEndProvider
 
destroyBackup(C) - Method in class com.hazelcast.spi.impl.merge.AbstractContainerCollector
Destroys the backup data in the container.
destroyCache(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
destroyContainer(int, ObjectNamespace) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
destroyContainer(String) - Method in class com.hazelcast.scheduledexecutor.impl.AbstractScheduledExecutorContainerHolder
 
destroyContainer(String) - Method in interface com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainerHolder
 
destroyDistributedObject(String, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
destroyDistributedObject(String, boolean) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorService
 
destroyDistributedObject(String, boolean) - Method in class com.hazelcast.collection.impl.collection.CollectionService
 
destroyDistributedObject(String) - Method in class com.hazelcast.collection.impl.list.ListService
 
destroyDistributedObject(String, boolean) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
destroyDistributedObject(String, boolean) - Method in class com.hazelcast.collection.impl.set.SetService
 
destroyDistributedObject(String, boolean) - Method in class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
 
destroyDistributedObject(String, boolean) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
 
destroyDistributedObject(String, boolean) - Method in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorService
 
destroyDistributedObject(String, boolean) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterService
 
destroyDistributedObject(String, boolean) - Method in class com.hazelcast.internal.longregister.LongRegisterService
 
destroyDistributedObject(String, boolean) - Method in interface com.hazelcast.internal.services.RemoteService
Destroys a distributed object.
destroyDistributedObject(String) - Method in interface com.hazelcast.internal.services.RemoteService
Destroys a distributed object on the cluster.
destroyDistributedObject(String, boolean) - Method in class com.hazelcast.map.impl.MapService
 
destroyDistributedObject(String, boolean) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
destroyDistributedObject(String, boolean) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
destroyDistributedObject(String, boolean) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
destroyDistributedObject(String, boolean) - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
destroyDistributedObject(String, String) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
 
destroyDistributedObject(String, String) - Method in interface com.hazelcast.spi.impl.proxyservice.ProxyService
 
destroyDistributedObject(String, boolean) - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicService
 
destroyDistributedObject(String, boolean) - Method in class com.hazelcast.topic.impl.TopicService
 
destroyDistributedObject(String, boolean) - Method in class com.hazelcast.transaction.impl.xa.XAService
 
destroyed - Variable in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueSnapshot
 
destroyedNames - Variable in class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
DestroyEventContext<T> - Interface in com.hazelcast.spi.tenantcontrol
Hook to decouple Hazelcast object from the tenant
destroyEventJournal() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
destroyIndexes() - Method in class com.hazelcast.query.impl.Indexes
Destroys and then removes all the indexes from this indexes instance.
destroyInternals() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
destroyInternals() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Like ICacheRecordStore.destroy() but does not touch state on other services like event journal service.
destroyLocalDistributedObject(String, String, boolean) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
 
destroyLocalDistributedObject(String, String, boolean) - Method in interface com.hazelcast.spi.impl.proxyservice.InternalProxyService
 
destroyLocally() - Method in class com.hazelcast.client.impl.spi.ClientProxy
Destroys this client proxy instance locally without issuing distributed object destroy request to the cluster as the ClientProxy.destroy() method does.
destroyLocalMapStatsImpl(String) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
 
destroyMap(String) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
destroyMap(MapContainer) - Method in class com.hazelcast.map.impl.PartitionContainer
 
destroyMapData(String) - Method in class com.hazelcast.wan.impl.DelegatingWanReplicationScheme
Releases all resources for the map with the given mapName.
destroyMapData(String) - Method in interface com.hazelcast.wan.impl.InternalWanReplicationPublisher
Releases all resources for the map with the given mapName.
destroyMapStores() - Method in interface com.hazelcast.map.impl.MapServiceContext
 
destroyMetaDataFor(String) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataGenerator
 
destroyNearCache(String) - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
 
destroyNearCache(String) - Method in interface com.hazelcast.internal.nearcache.NearCacheManager
Destroys NearCache instance associated with given name and also removes it.
destroyNearCache(String) - Method in class com.hazelcast.map.impl.nearcache.MapNearCacheManager
 
destroyProxy(ClientProxy) - Method in class com.hazelcast.client.impl.spi.ProxyManager
Destroys the given proxy in a cluster-wide way.
destroyProxyLocally(String, String) - Method in class com.hazelcast.client.impl.spi.ProxyManager
Locally destroys the proxy identified by the given service and object ID.
DestroyProxyMessageTask - Class in com.hazelcast.client.impl.protocol.task
 
DestroyProxyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
 
DestroyQueryCacheOperation - Class in com.hazelcast.map.impl.querycache.subscriber.operation
This operation removes all QueryCache resources on a node.
DestroyQueryCacheOperation() - Constructor for class com.hazelcast.map.impl.querycache.subscriber.operation.DestroyQueryCacheOperation
 
DestroyQueryCacheOperation(String, String) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.operation.DestroyQueryCacheOperation
 
DestroyRaftGroupCmd - Class in com.hazelcast.cp.internal.raft.command
A RaftGroupCmd to destroy an existing Raft group.
DestroyRaftGroupCmd() - Constructor for class com.hazelcast.cp.internal.raft.command.DestroyRaftGroupCmd
 
DestroyRaftGroupOp - Class in com.hazelcast.cp.internal.operation
Replicates a DestroyRaftGroupCmd to a Raft group.
DestroyRaftGroupOp() - Constructor for class com.hazelcast.cp.internal.operation.DestroyRaftGroupOp
 
DestroyRaftGroupOp(CPGroupId) - Constructor for class com.hazelcast.cp.internal.operation.DestroyRaftGroupOp
 
destroyRaftNode(CPGroupId) - Method in class com.hazelcast.cp.internal.RaftService
 
DestroyRaftNodesOp - Class in com.hazelcast.cp.internal.raftop.metadata
When a Raft group is destroyed, its members terminate their internal RaftNode instances.
DestroyRaftNodesOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.DestroyRaftNodesOp
 
DestroyRaftNodesOp(Collection<CPGroupId>) - Constructor for class com.hazelcast.cp.internal.raftop.metadata.DestroyRaftNodesOp
 
destroyRaftObject(CPGroupId, String) - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueService
 
destroyRaftObject(CPGroupId, String) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
destroyRaftObject(CPGroupId, String) - Method in interface com.hazelcast.cp.internal.datastructures.spi.RaftRemoteService
Destroys the given CP data structure on the CP group.
DestroyRaftObjectMessageTask - Class in com.hazelcast.cp.internal.datastructures.spi.client
Client message task for destroying Raft objects
DestroyRaftObjectMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.spi.client.DestroyRaftObjectMessageTask
 
DestroyRaftObjectOp - Class in com.hazelcast.cp.internal.datastructures.spi.operation
Destroys the distributed object with the given name on the requested Raft group
DestroyRaftObjectOp() - Constructor for class com.hazelcast.cp.internal.datastructures.spi.operation.DestroyRaftObjectOp
 
DestroyRaftObjectOp(String, String) - Constructor for class com.hazelcast.cp.internal.datastructures.spi.operation.DestroyRaftObjectOp
 
destroyRemotely() - Method in class com.hazelcast.client.impl.spi.ClientProxy
Destroys the remote distributed object counterpart of this proxy by issuing the destruction request to the cluster.
destroySegments(CacheConfig) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
destroyStorageAfterClear(boolean, boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
Calls also DefaultRecordStore.clearStorage(boolean) to release allocated HD memory of key+value pairs because DefaultRecordStore.destroyStorageImmediate(boolean, boolean) only releases internal resources of backing data structure.
destroyStore(Store) - Method in class com.hazelcast.spi.impl.merge.AbstractSplitBrainHandlerService
Destroys the given Store.
detectAndHandleBackupTimeout(long) - Method in class com.hazelcast.spi.impl.operationservice.impl.BaseInvocation
gets called from the Clean resources task
Diagnostics - Class in com.hazelcast.internal.diagnostics
The Diagnostics is a debugging tool that provides insight in all kinds of potential performance and stability issues.
Diagnostics(String, ILogger, String, HazelcastProperties) - Constructor for class com.hazelcast.internal.diagnostics.Diagnostics
 
DiagnosticsLogWriter - Interface in com.hazelcast.internal.diagnostics
 
DiagnosticsLogWriterImpl - Class in com.hazelcast.internal.diagnostics
A writer like structure dedicated for the DiagnosticsPlugin rendering.
DiagnosticsLogWriterImpl() - Constructor for class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
DiagnosticsLogWriterImpl(boolean) - Constructor for class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
DiagnosticsPlugin - Class in com.hazelcast.internal.diagnostics
Plugin for the Diagnostics.
DiagnosticsPlugin(ILogger) - Constructor for class com.hazelcast.internal.diagnostics.DiagnosticsPlugin
 
difference(IntHashSet) - Method in class com.hazelcast.internal.util.collection.IntHashSet
Fast Path set difference for comparison with another IntHashSet.
difference(LongHashSet) - Method in class com.hazelcast.internal.util.collection.LongHashSet
Fast Path set difference for comparison with another LongHashSet.
DIRECT_BUF - Static variable in class com.hazelcast.internal.networking.ChannelOption
If a direct buffer should be used or a regular buffer.
DIRECTORY - Static variable in class com.hazelcast.internal.diagnostics.Diagnostics
Configures the output directory of the performance log files.
DirectoryLock - Class in com.hazelcast.internal.util
A DirectoryLock represents a lock on a specific directory.
DISABLE_STALE_READ_ON_PARTITION_MIGRATION - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
disableAllGroups() - Method in class com.hazelcast.config.RestApiConfig
Disables all REST endpoint groups.
disableAllGroups() - Method in class com.hazelcast.config.RestServerEndpointConfig
Disables all REST endpoint groups.
disableDiscovery() - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
disableGroups(RestEndpointGroup...) - Method in class com.hazelcast.config.RestApiConfig
Disables provided REST endpoint groups.
disableGroups(RestEndpointGroup...) - Method in class com.hazelcast.config.RestServerEndpointConfig
Disables provided REST endpoint groups.
disablePerEntryInvalidationEvents - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
disablePerEntryInvalidationEvents - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
when true disables invalidation events for per entry but full-flush invalidation events are still enabled.
disableReentrancy() - Method in class com.hazelcast.config.cp.FencedLockConfig
Disable reentrancy.
disableWanReplicationEvent() - Method in class com.hazelcast.map.impl.operation.DeleteOperation
 
disableWanReplicationEvent() - Method in class com.hazelcast.map.impl.operation.MapOperation
 
disableWanReplicationEvent() - Method in class com.hazelcast.map.impl.operation.MergeOperation
 
disableWanReplicationEvent() - Method in class com.hazelcast.map.impl.operation.PutAllBackupOperation
 
disableWanReplicationEvent() - Method in class com.hazelcast.map.impl.operation.RemoveBackupOperation
 
DISCARD - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
DiscardMergePolicy<V,T extends MergingValue<V>> - Class in com.hazelcast.spi.merge
Merges only entries from the destination data structure and discards all entries from the source data structure.
DiscardMergePolicy() - Constructor for class com.hazelcast.spi.merge.DiscardMergePolicy
 
discoverLocalMetadata() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
 
discoverLocalMetadata() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
Returns a map with discovered metadata provided by the runtime environment.
discoverLocalMetadata() - Method in class com.hazelcast.spi.discovery.impl.DefaultDiscoveryService
 
discoverLocalMetadata() - Method in class com.hazelcast.spi.discovery.impl.PredefinedDiscoveryService
 
discoverLocalMetadata() - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryService
Returns a map with discovered metadata provided by the runtime environment.
discoverNodes() - Method in class com.hazelcast.client.impl.spi.impl.discovery.HazelcastCloudDiscovery
 
discoverNodes() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
Returns a set of all discovered nodes based on the defined properties that were used to create the DiscoveryStrategy instance.
discoverNodes() - Method in class com.hazelcast.spi.discovery.impl.DefaultDiscoveryService
 
discoverNodes() - Method in class com.hazelcast.spi.discovery.impl.PredefinedDiscoveryService
 
discoverNodes() - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryService
Returns a discovered and filtered, if a NodeFilter is setup, set of discovered nodes to connect to.
discoverNodes() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
 
DISCOVERY_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
DISCOVERY_SPI_ENABLED - Static variable in class com.hazelcast.client.properties.ClientProperty
Enables the Discovery SPI lookup over the old native implementations.
DISCOVERY_SPI_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Enables the Discovery SPI lookup over the old native implementations.
DISCOVERY_SPI_PUBLIC_IP_ENABLED - Static variable in class com.hazelcast.client.properties.ClientProperty
Enables the Discovery Joiner to use public ips from DiscoveredNode.
DISCOVERY_SPI_PUBLIC_IP_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Enables the Discovery Joiner to use public ips from DiscoveredNode.
DISCOVERY_STRATEGY_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
DiscoveryConfig - Class in com.hazelcast.config
This configuration class describes the top-level config of the discovery SPI and its discovery strategies.
DiscoveryConfig() - Constructor for class com.hazelcast.config.DiscoveryConfig
 
DiscoveryConfig(DiscoveryServiceProvider, NodeFilter, String, Collection<DiscoveryStrategyConfig>) - Constructor for class com.hazelcast.config.DiscoveryConfig
 
DiscoveryConfig(DiscoveryConfig) - Constructor for class com.hazelcast.config.DiscoveryConfig
 
DiscoveryConfigDTO - Class in com.hazelcast.internal.management.dto
A JSON representation of DiscoveryConfig.
DiscoveryConfigDTO() - Constructor for class com.hazelcast.internal.management.dto.DiscoveryConfigDTO
 
DiscoveryConfigDTO(DiscoveryConfig) - Constructor for class com.hazelcast.internal.management.dto.DiscoveryConfigDTO
 
DiscoveryConfigReadOnly - Class in com.hazelcast.internal.config
Readonly version of DiscoveryConfig
DiscoveryConfigReadOnly(DiscoveryConfig) - Constructor for class com.hazelcast.internal.config.DiscoveryConfigReadOnly
 
DiscoveryJoiner - Class in com.hazelcast.internal.cluster.impl
 
DiscoveryJoiner(Node, DiscoveryService, boolean) - Constructor for class com.hazelcast.internal.cluster.impl.DiscoveryJoiner
 
DiscoveryMode - Enum in com.hazelcast.spi.discovery.integration
The DiscoveryMode describes how the DiscoveryStrategy is going to behave on discovery requests.
DiscoveryNode - Class in com.hazelcast.spi.discovery
A DiscoveryNode describes a nodes addresses (private and if necessary a public one) as well as attributes assigned to this node.
DiscoveryNode() - Constructor for class com.hazelcast.spi.discovery.DiscoveryNode
 
discoveryService - Variable in class com.hazelcast.instance.impl.Node
 
DiscoveryService - Interface in com.hazelcast.spi.discovery.integration
The DiscoveryService interface defines the basic entry point into the Discovery SPI implementation.
DiscoveryServiceProvider - Interface in com.hazelcast.spi.discovery.integration
The DiscoveryServiceProvider interface provides the possibility to build DiscoveryServices.
DiscoveryServiceSettings - Class in com.hazelcast.spi.discovery.integration
The DiscoveryServiceSettings class is used to pass the necessary configuration to create a DiscoveryService to the DiscoveryServiceProvider.
DiscoveryServiceSettings() - Constructor for class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
DiscoveryStrategy - Interface in com.hazelcast.spi.discovery
The DiscoveryStrategy itself is the actual implementation to discover nodes based on whatever environment is used to run the Hazelcast cloud.
DiscoveryStrategyConfig - Class in com.hazelcast.config
This configuration class describes a DiscoveryStrategy based on a parsed XML or configured manually using the config API
DiscoveryStrategyConfig() - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyConfig(String) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyConfig(String, Map<String, Comparable>) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyConfig(DiscoveryStrategyFactory) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyConfig(DiscoveryStrategyFactory, Map<String, Comparable>) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyConfig(DiscoveryStrategyConfig) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
 
DiscoveryStrategyConfigDTO - Class in com.hazelcast.internal.management.dto
A JSON representation of DiscoveryStrategyConfig.
DiscoveryStrategyConfigDTO() - Constructor for class com.hazelcast.internal.management.dto.DiscoveryStrategyConfigDTO
 
DiscoveryStrategyConfigDTO(DiscoveryStrategyConfig) - Constructor for class com.hazelcast.internal.management.dto.DiscoveryStrategyConfigDTO
 
DiscoveryStrategyFactory - Interface in com.hazelcast.spi.discovery
The DiscoveryStrategyFactory is the entry point for strategy vendors.
dispatchBackupEvent(UUID, long) - Method in interface com.hazelcast.client.impl.ClientEngine
 
dispatchBackupEvent(UUID, long) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
dispatchBackupEvent(UUID, long) - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
dispatchEvent(Object, CacheEventListener) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
dispatchEvent(ClientEvent, ClientListener) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
dispatchEvent(CollectionEvent, ItemListener<Data>) - Method in class com.hazelcast.collection.impl.collection.CollectionService
 
dispatchEvent(QueueEvent, ItemListener) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
dispatchEvent(MembershipEvent, MembershipListener) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
dispatchEvent(PartitionEvent, PartitionEventListener<PartitionEvent>) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
dispatchEvent(Object, ListenerAdapter) - Method in class com.hazelcast.map.impl.event.MapEventPublishingService
 
dispatchEvent(Object, ListenerAdapter) - Method in class com.hazelcast.map.impl.MapService
 
dispatchEvent(EventData, EntryListener) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
dispatchEvent(Object, Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapEventPublishingService
 
dispatchEvent(Object, Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
dispatchEvent(E, T) - Method in interface com.hazelcast.spi.impl.eventservice.EventPublishingService
Notifies the service of a published event.
dispatchEvent(DistributedObjectEventPacket, Object) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
 
dispatchEvent(SplitBrainProtectionEvent, SplitBrainProtectionListener) - Method in class com.hazelcast.splitbrainprotection.impl.SplitBrainProtectionServiceImpl
 
dispatchEvent(Object, Object) - Method in class com.hazelcast.topic.impl.TopicService
 
dispatchFullQueryOnQueryThread(Query, Target) - Method in class com.hazelcast.map.impl.query.QueryEngineImpl
 
dispatchPartitionScanQueryOnOwnerMemberOnPartitionThread(Query, PartitionIdSet) - Method in class com.hazelcast.map.impl.query.QueryEngineImpl
 
dispatchPartitionScanQueryOnOwnerMemberOnPartitionThread(Query, int) - Method in class com.hazelcast.map.impl.query.QueryEngineImpl
 
Disposable - Interface in com.hazelcast.internal.nio
A Disposable is a container of data and/or resources that can be disposed.
dispose() - Method in class com.hazelcast.cache.impl.operation.CacheOperation
Implementers can override to release associated resources upon a successful execution or failure.
dispose() - Method in class com.hazelcast.client.impl.proxy.ClientScheduledFutureProxy
 
dispose(int) - Method in class com.hazelcast.durableexecutor.impl.TaskRingBuffer
Disposes the sequence
dispose() - Method in class com.hazelcast.internal.memory.impl.MemoryManagerBean
 
dispose() - Method in interface com.hazelcast.internal.nio.Disposable
Disposes this object and releases any data and/or resources associated with it.
dispose() - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
dispose() - Method in class com.hazelcast.internal.util.collection.HsaHeapMemoryManager
 
dispose() - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
 
dispose() - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
 
dispose() - Method in class com.hazelcast.internal.util.collection.LongSetHsa
 
dispose() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
dispose(String) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
dispose() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledFutureProxy
 
dispose() - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
Used to destroy the instance of the IScheduledFuture in the scheduled executor.
DISPOSE_BACKUP_TASK_OP - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
DISPOSE_RESULT - Static variable in class com.hazelcast.durableexecutor.impl.DurableExecutorDataSerializerHook
 
DISPOSE_RESULT_BACKUP - Static variable in class com.hazelcast.durableexecutor.impl.DurableExecutorDataSerializerHook
 
DISPOSE_TASK_OP - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
DisposeBackupTaskOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
DisposeBackupTaskOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.DisposeBackupTaskOperation
 
DisposeBackupTaskOperation(String, String) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.DisposeBackupTaskOperation
 
disposeData(Data) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
disposeData(Data) - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
 
disposeDeferredBlocks() - Method in class com.hazelcast.cache.impl.CacheRecordStore
 
disposeDeferredBlocks() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
 
disposeDeferredBlocks - Variable in class com.hazelcast.map.impl.operation.MapOperation
 
disposeDeferredBlocks() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
This can be used to release unused resources.
disposeDeferredBlocks() - Method in interface com.hazelcast.map.impl.recordstore.Storage
 
disposeDeferredBlocks() - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
disposeResult(long) - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
disposeResult(long) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Disposes the result with the given taskId
disposeResult(int) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorContainer
 
disposeResult(long) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
DisposeResultBackupOperation - Class in com.hazelcast.durableexecutor.impl.operations
 
DisposeResultBackupOperation() - Constructor for class com.hazelcast.durableexecutor.impl.operations.DisposeResultBackupOperation
 
DisposeResultOperation - Class in com.hazelcast.durableexecutor.impl.operations
 
DisposeResultOperation() - Constructor for class com.hazelcast.durableexecutor.impl.operations.DisposeResultOperation
 
DisposeResultOperation(String, int) - Constructor for class com.hazelcast.durableexecutor.impl.operations.DisposeResultOperation
 
DisposeTaskOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
DisposeTaskOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.DisposeTaskOperation
 
DisposeTaskOperation(ScheduledTaskHandler) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.DisposeTaskOperation
 
DIST_OBJECT_DESTROY - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
DIST_OBJECT_INIT - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
distinct() - Static method in class com.hazelcast.aggregation.Aggregators
 
distinct(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
DISTINCT_VALUES - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
DistinctValuesAggregator<I,R> - Class in com.hazelcast.aggregation.impl
 
DistinctValuesAggregator() - Constructor for class com.hazelcast.aggregation.impl.DistinctValuesAggregator
 
DistinctValuesAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.DistinctValuesAggregator
 
DISTRIBUTED_OBJECT_DESTROYED - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
DISTRIBUTED_OBJECT_EVENT - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
 
DISTRIBUTED_OBJECT_NS - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
DistributedDurableExecutorService - Class in com.hazelcast.durableexecutor.impl
 
DistributedDurableExecutorService(NodeEngineImpl) - Constructor for class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
 
DistributedExecutorService - Class in com.hazelcast.executor.impl
 
DistributedExecutorService() - Constructor for class com.hazelcast.executor.impl.DistributedExecutorService
 
DistributedObject - Interface in com.hazelcast.core
Base interface for all distributed objects.
distributedObject - Variable in class com.hazelcast.core.DistributedObjectEvent
 
distributedObjectCreated(DistributedObjectEvent) - Method in class com.hazelcast.client.impl.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.internal.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.internal.jmx.ManagementService
 
DistributedObjectDestroyedException - Exception in com.hazelcast.spi.exception
A HazelcastException that indicates that a DistributedObject access was attempted, but the object is destroyed.
DistributedObjectDestroyedException(String) - Constructor for exception com.hazelcast.spi.exception.DistributedObjectDestroyedException
 
DistributedObjectDestroyOperation - Class in com.hazelcast.spi.impl.proxyservice.impl.operations
 
DistributedObjectDestroyOperation() - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.operations.DistributedObjectDestroyOperation
 
DistributedObjectDestroyOperation(String, String) - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.operations.DistributedObjectDestroyOperation
 
DistributedObjectEvent - Class in com.hazelcast.core
DistributedObjectEvent is fired when a DistributedObject is created or destroyed cluster-wide.
DistributedObjectEvent(DistributedObjectEvent.EventType, String, String, DistributedObject) - Constructor for class com.hazelcast.core.DistributedObjectEvent
Constructs a DistributedObject Event.
DistributedObjectEvent.EventType - Enum in com.hazelcast.core
Type of the DistributedObjectEvent.
DistributedObjectEventPacket - Class in com.hazelcast.spi.impl.proxyservice.impl
 
DistributedObjectEventPacket() - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectEventPacket
 
DistributedObjectEventPacket(DistributedObjectEvent.EventType, String, String) - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectEventPacket
 
DistributedObjectFuture - Class in com.hazelcast.spi.impl.proxyservice.impl
 
DistributedObjectFuture() - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectFuture
 
DistributedObjectInfo - Class in com.hazelcast.client.impl.client
 
DistributedObjectInfo() - Constructor for class com.hazelcast.client.impl.client.DistributedObjectInfo
 
DistributedObjectInfo(String, String) - Constructor for class com.hazelcast.client.impl.client.DistributedObjectInfo
 
DistributedObjectInfoCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
DistributedObjectListener - Interface in com.hazelcast.core
DistributedObjectListener notifies when a DistributedObject is created or destroyed cluster-wide.
DistributedObjectNamespace - Class in com.hazelcast.internal.services
Default ObjectNamespace implementation for DistributedObject.
DistributedObjectNamespace() - Constructor for class com.hazelcast.internal.services.DistributedObjectNamespace
 
DistributedObjectNamespace(String, String) - Constructor for class com.hazelcast.internal.services.DistributedObjectNamespace
 
DistributedObjectNamespace(ObjectNamespace) - Constructor for class com.hazelcast.internal.services.DistributedObjectNamespace
 
DistributedObjectUtil - Class in com.hazelcast.core
Utility class for DistributedObject.
DistributedScheduledExecutorService - Class in com.hazelcast.scheduledexecutor.impl
Scheduled executor service, middle-man responsible for managing Scheduled Executor containers.
DistributedScheduledExecutorService() - Constructor for class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
DistributedServiceWanEventCounters - Class in com.hazelcast.wan
Counters for WAN events for a single distributed object type (map or cache).
DistributedServiceWanEventCounters() - Constructor for class com.hazelcast.wan.DistributedServiceWanEventCounters
 
DistributedServiceWanEventCounters.DistributedObjectWanEventCounters - Class in com.hazelcast.wan
Counters for WAN events for a single map or cache.
DISTRIBUTION - Static variable in class com.hazelcast.instance.GeneratedBuildProperties
 
divideByAndCeilToInt(double, int) - Static method in class com.hazelcast.internal.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.internal.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.internal.util.QuickMath
Divide d by k and return the int value closest to the result.
divideByAndRoundToLong(double, int) - Static method in class com.hazelcast.internal.util.QuickMath
Divide d by k and return the long value closest to the result.
DO_NOT_REDUCE - Static variable in class com.hazelcast.query.impl.getters.AbstractMultiValueGetter
 
doBegin(Object, TransactionDefinition) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
doCleanupAfterCompletion(Object) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
doCommit(DefaultTransactionStatus) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
doEviction(boolean) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
doEviction(boolean) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
Does eviction as specified configuration EvictionConfig in NearCacheConfig.
doExpiration() - Method in class com.hazelcast.internal.nearcache.impl.store.BaseHeapNearCacheRecordStore
 
doExpiration() - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
Performs expiration and evicts expired records.
doFilter(EventFilter, Data, Object, Object, EntryEventType, String) - Method in class com.hazelcast.map.impl.event.DefaultEntryEventFilteringStrategy
Main entry point for filtering events according to given filter.
doFilter(EventFilter, Data, Object, Object, EntryEventType, String) - Method in interface com.hazelcast.map.impl.event.FilteringStrategy
Main entry point for filtering events according to given filter.
doFilter(EventFilter, Data, Object, Object, EntryEventType, String) - Method in class com.hazelcast.map.impl.event.QueryCacheNaturalFilteringStrategy
 
doGetLockOwnershipState() - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
doGetLockOwnershipState() - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.FencedLockProxy
 
doGetTransaction() - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
doJoin() - Method in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
doJoin() - Method in class com.hazelcast.internal.cluster.impl.MulticastJoiner
 
doJoin() - Method in class com.hazelcast.internal.cluster.impl.TcpIpJoiner
 
doLock(long, long, UUID) - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
doLock(long, long, UUID) - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.FencedLockProxy
 
doMatch(String, String, int) - Method in class com.hazelcast.internal.util.AddressUtil.AddressMatcher
 
DomConfigHelper - Class in com.hazelcast.config
Helper class for accessing and extracting values from W3C DOM Node instances
DomConfigProcessor - Interface in com.hazelcast.config
Interface used by XML and YAML configuration classes for traversing and filling config object graph.
domLevel3 - Variable in class com.hazelcast.config.AbstractDomConfigProcessor
Tells whether the traversed DOM is a level 3 one
domLevel3 - Variable in class com.hazelcast.config.AbstractXmlConfigHelper
 
DONE_RESPONSE - Static variable in class com.hazelcast.spi.impl.operationservice.CallStatus
Signals that the Operation is done running and that a response is ready to be returned.
DONE_RESPONSE_ORDINAL - Static variable in class com.hazelcast.spi.impl.operationservice.CallStatus
The ordinal value for a CallStatus.DONE_RESPONSE.
DONE_VOID - Static variable in class com.hazelcast.spi.impl.operationservice.CallStatus
Signals that the Operation is done running, but no response will be returned.
DONE_VOID_BACKUP - Static variable in class com.hazelcast.spi.impl.operationservice.CallStatus
Signals that the Operation is done running, its backup should be sent, but no response will be returned.
DONE_VOID_BACKUP_ORDINAL - Static variable in class com.hazelcast.spi.impl.operationservice.CallStatus
The ordinal value for an CallStatus.DONE_VOID_BACKUP.
DONE_VOID_ORDINAL - Static variable in class com.hazelcast.spi.impl.operationservice.CallStatus
The ordinal value for a CallStatus.DONE_VOID.
doneCallback - Variable in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
 
doneProcessing() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
dontCreateCacheRecordStoreIfNotExist - Variable in class com.hazelcast.cache.impl.operation.CacheOperation
 
doPostEvictionOperations(Record) - Method in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
doPostEvictionOperations(Record) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Does post eviction operations like sending events
doPostOperateOps() - Method in class com.hazelcast.map.impl.operation.EntryOperator
 
doPrepublicationChecks(String) - Method in class com.hazelcast.cache.impl.CacheService
 
doPrepublicationChecks(String) - Method in interface com.hazelcast.cache.impl.ICacheService
 
doPrepublicationChecks() - Method in class com.hazelcast.wan.impl.DelegatingWanReplicationScheme
 
doPrepublicationChecks() - Method in interface com.hazelcast.wan.WanReplicationPublisher
Performs pre-publication checks (e.g.
doPutRecord(Data, R, UUID, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
doRemoveRecord(Data, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
doResume(Object, Object) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
doRollback(DefaultTransactionStatus) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
doSetRollbackOnly(DefaultTransactionStatus) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
doShutdown() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
doSuspend(Object) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
doTryLock(long, long, UUID, long) - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
doTryLock(long, long, UUID, long) - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.FencedLockProxy
 
DOUBLE_AVG - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
DOUBLE_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
DOUBLE_SIZE_IN_BYTES - Static variable in class com.hazelcast.internal.nio.Bits
Double size in bytes
DOUBLE_SUM - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
DoubleArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.DoubleArraySerializer
 
DoubleAverageAggregator<I> - Class in com.hazelcast.aggregation.impl
 
DoubleAverageAggregator() - Constructor for class com.hazelcast.aggregation.impl.DoubleAverageAggregator
 
DoubleAverageAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.DoubleAverageAggregator
 
doubleAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
doubleAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
DoubleGauge - Interface in com.hazelcast.internal.metrics
A DoubleGauge is a Gauge where a particular double value is read instantaneously.
doubleMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
doubleMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
doubleMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
doubleMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
DoubleProbeFunction<S> - Interface in com.hazelcast.internal.metrics
A ProbeFunction that provides a double value and can be used to create a probe using MetricsRegistry.registerStaticProbe(Object, String, ProbeLevel, LongProbeFunction)
DoubleSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.DoubleSerializer
 
doubleSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
doubleSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
DoubleSumAggregator<I> - Class in com.hazelcast.aggregation.impl
 
DoubleSumAggregator() - Constructor for class com.hazelcast.aggregation.impl.DoubleSumAggregator
 
DoubleSumAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.DoubleSumAggregator
 
doUnlock(long, long, UUID) - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
doUnlock(long, long, UUID) - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.FencedLockProxy
 
drain(int) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Removes items from the queue and the queue store (if configured), up to maxSize or the size of the queue, whichever is smaller.
DRAIN - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
drain() - Method in class com.hazelcast.internal.jmx.SemaphoreMBean
 
drain(int, Predicate<? super E>) - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Drains a batch of items from the queue at the supplied index to the supplied itemHandler.
drain(Predicate<? super E>) - Method in class com.hazelcast.internal.util.concurrent.ManyToOneConcurrentArrayQueue
 
drain(Predicate<? super E>) - Method in class com.hazelcast.internal.util.concurrent.OneToOneConcurrentArrayQueue
 
drain(Predicate<? super E>) - Method in interface com.hazelcast.internal.util.concurrent.Pipe
Drains the items available in the pipe to the supplied item handler.
DRAIN_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
DRAIN_PERMITS_OP - Static variable in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreDataSerializerHook
 
DRAIN_SESSION_ACQ_COUNT - Static variable in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionAwareSemaphoreProxy
Since a proxy does not know how many permits will be drained on the Raft group, it uses this constant to increment its local session acquire count.
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
 
drainerArrived() - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Called by the drainer thread to signal that it has started draining the queue.
drainerDone() - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Called by the drainer thread to signal that it is done draining the queue.
drainerFailed(Throwable) - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Called by the drainer thread to signal that it has failed and will drain no more items from the queue.
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
 
drainPermits() - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionAwareSemaphoreProxy
 
drainPermits() - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionlessSemaphoreProxy
 
drainPermits() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionAwareSemaphoreProxy
 
drainPermits() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionlessSemaphoreProxy
 
drainPermits(CPGroupId, String, long, SemaphoreEndpoint, UUID) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreService
 
drainPermits() - Method in interface com.hazelcast.cp.ISemaphore
Acquires and returns all permits that are available at invocation time.
DrainPermitsMessageTask - Class in com.hazelcast.cp.internal.datastructures.semaphore.client
Client message task for DrainPermitsOp
DrainPermitsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.client.DrainPermitsMessageTask
 
DrainPermitsOp - Class in com.hazelcast.cp.internal.datastructures.semaphore.operation
DrainPermitsOp() - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.operation.DrainPermitsOp
 
DrainPermitsOp(String, long, long, UUID) - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.operation.DrainPermitsOp
 
drainQueue(Queue<?>) - Static method in class com.hazelcast.internal.util.QueueUtil
Drains the provided queue by the size of the queue as it is known upfront draining.
drainQueue(Queue<E>, Predicate<E>) - Static method in class com.hazelcast.internal.util.QueueUtil
Drains the provided queue by the size of the queue as it is known upfront draining.
drainQueue(Queue<E>, int, Predicate<E>) - Static method in class com.hazelcast.internal.util.QueueUtil
Drains the provided queue by the count provided in elementsToDrain.
drainTo(Collection<? super E>) - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
drainTo(Collection<? super E>, int) - Method in class com.hazelcast.client.impl.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(InputStream, OutputStream) - Static method in class com.hazelcast.internal.nio.IOUtil
 
drainTo(InputStream, OutputStream, int) - Static method in class com.hazelcast.internal.nio.IOUtil
Writes len bytes from the given input stream to the given output stream.
drainTo(Collection<? super E>) - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Drains a batch of items from the default queue into the supplied collection.
drainTo(int, Collection<? super E>) - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Drains a batch of items from the queue at the supplied index into the supplied collection.
drainTo(Collection<? super E>, int) - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Drains no more than limit items from the default queue into the supplied collection.
drainTo(int, Collection<? super E>, int) - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Drains no more than limit items from the queue at the supplied index into the supplied collection.
drainTo(Collection<? super E>, int) - Method in class com.hazelcast.internal.util.concurrent.ManyToOneConcurrentArrayQueue
 
drainTo(Collection<? super E>) - Method in class com.hazelcast.internal.util.concurrent.MPSCQueue
 
drainTo(Collection<? super E>, int) - Method in class com.hazelcast.internal.util.concurrent.MPSCQueue
 
drainTo(Collection<? super E>, int) - Method in class com.hazelcast.internal.util.concurrent.OneToOneConcurrentArrayQueue
 
drainTo(Collection<? super E>, int) - Method in interface com.hazelcast.internal.util.concurrent.Pipe
Drains at most limit available items into the provided Collection.
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.
dst - Variable in class com.hazelcast.internal.networking.ChannelHandler
 
dst() - Method in class com.hazelcast.internal.networking.ChannelHandler
Gets the destination of this ChannelHandler.
dst(D) - Method in class com.hazelcast.internal.networking.ChannelHandler
Sets the destination of this ChannelHandler.
dumpAllThreads() - Static method in class com.hazelcast.internal.management.ThreadDumpGenerator
 
dumpDeadlocks() - Static method in class com.hazelcast.internal.management.ThreadDumpGenerator
 
DUPLICATE_INSTANCE_NAME - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
DUPLICATE_TASK - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
DuplicateDetectingMultiResult - Class in com.hazelcast.query.impl
 
DuplicateDetectingMultiResult() - Constructor for class com.hazelcast.query.impl.DuplicateDetectingMultiResult
 
DuplicateTaskException - Exception in com.hazelcast.scheduledexecutor
An exception thrown when a task's name is already used before for another (or the same, if re-attempted) schedule.
DuplicateTaskException(String) - Constructor for exception com.hazelcast.scheduledexecutor.DuplicateTaskException
 
durability - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddDurableExecutorConfigCodec.RequestParameters
executor's durability
durability - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddScheduledExecutorConfigCodec.RequestParameters
durability of the scheduled executor
durability - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionCreateCodec.RequestParameters
The durability of the transaction
DURABLE_EXECUTOR_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
DURABLE_EXECUTOR_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
DURABLE_EXECUTOR_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
DurableExecutorConfig - Class in com.hazelcast.config
Contains the configuration for an DurableExecutorService.
DurableExecutorConfig() - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorConfig(String) - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorConfig(String, int, int, int) - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorConfig(String, int, int, int, String) - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorConfig(DurableExecutorConfig) - Constructor for class com.hazelcast.config.DurableExecutorConfig
 
DurableExecutorConfigReadOnly - Class in com.hazelcast.internal.config
 
DurableExecutorConfigReadOnly(DurableExecutorConfig) - Constructor for class com.hazelcast.internal.config.DurableExecutorConfigReadOnly
 
DurableExecutorContainer - Class in com.hazelcast.durableexecutor.impl
 
DurableExecutorContainer(NodeEngineImpl, String, int, int, TaskRingBuffer) - Constructor for class com.hazelcast.durableexecutor.impl.DurableExecutorContainer
 
DurableExecutorContainer.TaskProcessor - Class in com.hazelcast.durableexecutor.impl
 
DurableExecutorDataSerializerHook - Class in com.hazelcast.durableexecutor.impl
 
DurableExecutorDataSerializerHook() - Constructor for class com.hazelcast.durableexecutor.impl.DurableExecutorDataSerializerHook
 
DurableExecutorDisposeResultCodec - Class in com.hazelcast.client.impl.protocol.codec
Disposes the result of the execution with the given sequence
DurableExecutorDisposeResultCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DurableExecutorDisposeResultCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DurableExecutorDisposeResultMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice.durable
 
DurableExecutorDisposeResultMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorDisposeResultMessageTask
 
DurableExecutorIsShutdownCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns true if this executor has been shut down.
DurableExecutorIsShutdownCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DurableExecutorIsShutdownCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DurableExecutorIsShutdownMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice.durable
 
DurableExecutorIsShutdownMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorIsShutdownMessageTask
 
DurableExecutorPartitionContainer - Class in com.hazelcast.durableexecutor.impl
 
DurableExecutorPartitionContainer(NodeEngineImpl, int) - Constructor for class com.hazelcast.durableexecutor.impl.DurableExecutorPartitionContainer
 
DurableExecutorRetrieveAndDisposeResultCodec - Class in com.hazelcast.client.impl.protocol.codec
Retrieves and disposes the result of the execution with the given sequence
DurableExecutorRetrieveAndDisposeResultCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DurableExecutorRetrieveAndDisposeResultCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DurableExecutorRetrieveAndDisposeResultMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice.durable
 
DurableExecutorRetrieveAndDisposeResultMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveAndDisposeResultMessageTask
 
DurableExecutorRetrieveResultCodec - Class in com.hazelcast.client.impl.protocol.codec
Retrieves the result of the execution with the given sequence
DurableExecutorRetrieveResultCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DurableExecutorRetrieveResultCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DurableExecutorRetrieveResultMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice.durable
 
DurableExecutorRetrieveResultMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveResultMessageTask
 
DurableExecutorService - Interface in com.hazelcast.durableexecutor
Durable implementation of ExecutorService.
DurableExecutorServiceFuture<V> - Interface in com.hazelcast.durableexecutor
A Future where one can obtain the task ID for tracking the response.
DurableExecutorServicePermission - Class in com.hazelcast.security.permission
 
DurableExecutorServicePermission(String, String...) - Constructor for class com.hazelcast.security.permission.DurableExecutorServicePermission
 
DurableExecutorServiceProxy - Class in com.hazelcast.durableexecutor.impl
 
DurableExecutorShutdownCodec - Class in com.hazelcast.client.impl.protocol.codec
Initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
DurableExecutorShutdownCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DurableExecutorShutdownCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DurableExecutorShutdownMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice.durable
 
DurableExecutorShutdownMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorShutdownMessageTask
 
DurableExecutorSubmitToPartitionCodec - Class in com.hazelcast.client.impl.protocol.codec
Submits the task to partition for execution
DurableExecutorSubmitToPartitionCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DurableExecutorSubmitToPartitionCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DurableExecutorSubmitToPartitionMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice.durable
 
DurableExecutorSubmitToPartitionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorSubmitToPartitionMessageTask
 
DurableExecutorWaitNotifyKey - Class in com.hazelcast.durableexecutor.impl.operations
 
DurableIterator() - Constructor for class com.hazelcast.durableexecutor.impl.TaskRingBuffer.DurableIterator
 
DurationConfig() - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
DurationConfig(long, TimeUnit) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
DurationConfigCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
durationMs - Variable in class com.hazelcast.internal.management.dto.SlowOperationInvocationDTO
 
DYNAMIC_CONFIG_PRE_JOIN_OP - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
DynamicConfigAddCacheConfigCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a new cache configuration to a running cluster.
DynamicConfigAddCacheConfigCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddCacheConfigCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddCardinalityEstimatorConfigCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a new cardinality estimator configuration to a running cluster.
DynamicConfigAddCardinalityEstimatorConfigCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddCardinalityEstimatorConfigCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddDurableExecutorConfigCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a new durable executor configuration to a running cluster.
DynamicConfigAddDurableExecutorConfigCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddDurableExecutorConfigCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddExecutorConfigCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a new executor configuration to a running cluster.
DynamicConfigAddExecutorConfigCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddExecutorConfigCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddFlakeIdGeneratorConfigCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a new flake ID generator configuration to a running cluster.
DynamicConfigAddFlakeIdGeneratorConfigCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddFlakeIdGeneratorConfigCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddListConfigCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a new list configuration to a running cluster.
DynamicConfigAddListConfigCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddListConfigCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddMapConfigCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a new map configuration to a running cluster.
DynamicConfigAddMapConfigCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddMapConfigCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddMultiMapConfigCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a new multimap config to a running cluster.
DynamicConfigAddMultiMapConfigCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddMultiMapConfigCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddPNCounterConfigCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a new CRDT PN counter configuration to a running cluster.
DynamicConfigAddPNCounterConfigCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddPNCounterConfigCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddQueueConfigCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a new queue configuration to a running cluster.
DynamicConfigAddQueueConfigCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddQueueConfigCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddReliableTopicConfigCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a new reliable topic configuration to a running cluster.
DynamicConfigAddReliableTopicConfigCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddReliableTopicConfigCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddReplicatedMapConfigCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a new replicated map configuration to a running cluster.
DynamicConfigAddReplicatedMapConfigCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddReplicatedMapConfigCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddRingbufferConfigCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a new ringbuffer configuration to a running cluster.
DynamicConfigAddRingbufferConfigCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddRingbufferConfigCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddScheduledExecutorConfigCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a new scheduled executor configuration to a running cluster.
DynamicConfigAddScheduledExecutorConfigCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddScheduledExecutorConfigCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddSetConfigCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a new set configuration to a running cluster.
DynamicConfigAddSetConfigCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddSetConfigCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddTopicConfigCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a new topic configuration to a running cluster.
DynamicConfigAddTopicConfigCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigAddTopicConfigCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
DynamicConfigListener - Interface in com.hazelcast.internal.dynamicconfig
Listener to be notified about various events in ClusterWideConfigurationService
DynamicConfigPreJoinOperation - Class in com.hazelcast.internal.dynamicconfig
 
DynamicConfigPreJoinOperation(IdentifiedDataSerializable[], ConfigCheckMode) - Constructor for class com.hazelcast.internal.dynamicconfig.DynamicConfigPreJoinOperation
 
DynamicConfigPreJoinOperation() - Constructor for class com.hazelcast.internal.dynamicconfig.DynamicConfigPreJoinOperation
 
DynamicConfigurationAwareConfig - Class in com.hazelcast.internal.dynamicconfig
 
DynamicConfigurationAwareConfig(Config, HazelcastProperties) - Constructor for class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
DynamicMetricsProvider - Interface in com.hazelcast.internal.metrics
Interface to be implemented by the classes that expose metrics in a dynamic fashion.
DynamicSecurityConfig - Class in com.hazelcast.internal.dynamicconfig
SecurityConfig wrapper that supports dynamically updating client permissions.
DynamicSecurityConfig(SecurityConfig, SecurityService) - Constructor for class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 

E

Echo - Class in com.hazelcast.console
Echoes to screen.
Echo() - Constructor for class com.hazelcast.console.Echo
 
Echo(String) - Constructor for class com.hazelcast.console.Echo
 
element() - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
element() - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
element1 - Variable in class com.hazelcast.internal.util.BiTuple
 
element1() - Method in class com.hazelcast.internal.util.BiTuple
 
element1 - Variable in class com.hazelcast.internal.util.TriTuple
 
element2 - Variable in class com.hazelcast.internal.util.BiTuple
 
element2() - Method in class com.hazelcast.internal.util.BiTuple
 
element2 - Variable in class com.hazelcast.internal.util.TriTuple
 
element3 - Variable in class com.hazelcast.internal.util.TriTuple
 
ElementAdapter - Class in com.hazelcast.internal.config.yaml
Class adapting YamlNodes to Element.
ElementParser - Class in com.hazelcast.buildutils
Originally taken from JBOSS project (thanks guys, great work) Original class: org.jboss.osgi.metadata.spi.ElementParser -> JBossOSGi Resolver Metadata
elements - Variable in class com.hazelcast.client.impl.protocol.codec.MetricsReadMetricsCodec.ResponseParameters
The map of timestamp and compressed metrics data
elements() - Method in class com.hazelcast.internal.metrics.managementcenter.ConcurrentArrayRingbuffer.RingbufferSlice
 
elements() - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
Returns an enumeration of the values in this table.
elements() - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
elements() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
elements() - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
EMPTY - Static variable in interface com.hazelcast.monitor.impl.IndexesStats
Empty no-op internal indexes stats.
EMPTY - Static variable in interface com.hazelcast.monitor.impl.IndexOperationStats
Empty no-op index operation stats instance.
EMPTY - Static variable in interface com.hazelcast.monitor.impl.PerIndexStats
Empty no-op internal index stats instance.
EMPTY_COUNTER - Static variable in interface com.hazelcast.map.impl.mapstore.writebehind.TxnReservedCapacityCounter
Used when MapStoreConfig.writeCoalescing is enabled.
EMPTY_LOCAL_MAP_STATS - Static variable in class com.hazelcast.map.impl.LocalMapStatsProvider
 
EMPTY_MAP_DATA_STORE - Static variable in class com.hazelcast.map.impl.mapstore.MapDataStores
 
emptyCollection(MultiMapConfig.ValueCollectionType) - Static method in class com.hazelcast.multimap.impl.ValueCollectionFactory
Picks right empty collection type, like Collections.emptySet() or Collections.emptyList() )} depending on the MultiMapConfig.getValueCollectionType()
emptyDelayedEntry() - Static method in class com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntries
 
EmptyDynamicConfigListener - Class in com.hazelcast.internal.dynamicconfig
Empty implementation of DynamicConfigListener
EmptyDynamicConfigListener() - Constructor for class com.hazelcast.internal.dynamicconfig.EmptyDynamicConfigListener
 
EmptyIterator() - Constructor for class com.hazelcast.spi.impl.merge.AbstractContainerCollector.EmptyIterator
 
EmptyLocalReplicatedMapStats - Class in com.hazelcast.monitor.impl
Implementation of LocalReplicatedMapStats with empty and immutable inner state.
EmptyLocalReplicatedMapStats() - Constructor for class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
emptyMapStoreManager() - Static method in class com.hazelcast.map.impl.mapstore.MapStoreManagers
 
EmptyOptimizer - Class in com.hazelcast.query.impl.predicates
Optimizer which just returns the original predicate.
EmptyOptimizer() - Constructor for class com.hazelcast.query.impl.predicates.EmptyOptimizer
 
emptyQueueTtl - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddQueueConfigCodec.RequestParameters
queue time-to-live in seconds: queue will be destroyed if it stays empty or unused for that time
EmptyStatement - Class in com.hazelcast.internal.util
This class makes CheckStyle happy, if you have an ignored or expected exception, but need at least a single statement in the catch clause.
ENABLE_JMX - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
enableAllGroups() - Method in class com.hazelcast.config.RestApiConfig
Enables all REST endpoint groups.
enableAllGroups() - Method in class com.hazelcast.config.RestServerEndpointConfig
Enables all REST endpoint groups.
enableCompression - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
enabled - Variable in class com.hazelcast.client.impl.protocol.codec.CacheManagementConfigCodec.RequestParameters
true if enabled, false to disable.
ENABLED - Static variable in class com.hazelcast.client.impl.statistics.Statistics
Use to enable the client statistics collection.
enabled - Variable in class com.hazelcast.config.SplitBrainProtectionConfigBuilder
Whether this split brain protection config is enabled or not
enabled(boolean) - Method in class com.hazelcast.config.SplitBrainProtectionConfigBuilder
 
ENABLED - Static variable in class com.hazelcast.internal.diagnostics.Diagnostics
Use the Diagnostics to see internal performance metrics and cluster related information.
ENABLED - Static variable in class com.hazelcast.internal.diagnostics.SystemLogPlugin
If this plugin is enabled.
enabled() - Method in class com.hazelcast.internal.util.ConcurrencyDetection
Checks if this ConcurrencyDetection is enabled.
enableGroups(RestEndpointGroup...) - Method in class com.hazelcast.config.RestApiConfig
Enables provided REST endpoint groups.
enableGroups(RestEndpointGroup...) - Method in class com.hazelcast.config.RestServerEndpointConfig
Enables provided REST endpoint groups.
enableManagement(String, boolean) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
 
enableManagement(String, boolean) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
 
enableReentrancy() - Method in class com.hazelcast.config.cp.FencedLockConfig
Enables reentrancy.
enableSharedObject - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
enableStatistics(String, boolean) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
 
enableStatistics(String, boolean) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
 
encode(ClientMessage, byte[]) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ByteArrayCodec
 
encode(ClientMessage, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.DataCodec
 
encode(ClientMessage, Collection<Map.Entry<K, V>>, BiConsumer<ClientMessage, K>, BiConsumer<ClientMessage, V>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.EntryListCodec
 
encode(ClientMessage, Collection<Map.Entry<Integer, Long>>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.EntryListIntegerLongCodec
 
encode(ClientMessage, Collection<Map.Entry<Integer, UUID>>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.EntryListIntegerUUIDCodec
 
encode(ClientMessage, Collection<Map.Entry<Long, byte[]>>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.EntryListLongByteArrayCodec
 
encode(ClientMessage, Collection<Map.Entry<UUID, Long>>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.EntryListUUIDLongCodec
 
encode(List<ErrorHolder>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ErrorsCodec
 
encode(ClientMessage, Collection<Integer>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ListIntegerCodec
 
encode(ClientMessage, Collection<Long>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ListLongCodec
 
encode(ClientMessage, Collection<T>, BiConsumer<ClientMessage, T>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ListMultiFrameCodec
 
encode(ClientMessage, Collection<ScheduledTaskHandler>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ListScheduledTaskHandlerCodec
 
encode(ClientMessage, Collection<UUID>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ListUUIDCodec
 
encode(ClientMessage, long[]) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.LongArrayCodec
 
encode(ClientMessage, Map<K, V>, BiConsumer<ClientMessage, K>, BiConsumer<ClientMessage, V>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.MapCodec
 
encode(ClientMessage, String) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.StringCodec
 
encode(ClientMessage, TimeUnit) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.StringCodec
 
encode(ClientMessage, CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.StringCodec
 
encode(ClientMessage, Address) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.AddressCodec
 
encode(ClientMessage, AttributeConfig) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.AttributeConfigCodec
 
encode(ClientMessage, CacheConfigHolder) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.CacheConfigHolderCodec
 
encode(ClientMessage, CacheEventData) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.CacheEventDataCodec
 
encode(ClientMessage, CacheSimpleEntryListenerConfig) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.CacheSimpleEntryListenerConfigCodec
 
encode(ClientMessage, DistributedObjectInfo) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.DistributedObjectInfoCodec
 
encode(ClientMessage, CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.DurationConfigCodec
 
encode(ClientMessage, ErrorHolder) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.ErrorHolderCodec
 
encode(ClientMessage, EventJournalConfig) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.EventJournalConfigCodec
 
encode(ClientMessage, EvictionConfigHolder) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.EvictionConfigHolderCodec
 
encode(ClientMessage, HotRestartConfig) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.HotRestartConfigCodec
 
encode(ClientMessage, IndexConfig) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.IndexConfigCodec
 
encode(ClientMessage, ListenerConfigHolder) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.ListenerConfigHolderCodec
 
encode(ClientMessage, MapStoreConfigHolder) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.MapStoreConfigHolderCodec
 
encode(ClientMessage, Member) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.MemberCodec
 
encode(ClientMessage, MergePolicyConfig) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.MergePolicyConfigCodec
 
encode(ClientMessage, MerkleTreeConfig) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.MerkleTreeConfigCodec
 
encode(ClientMessage, NearCacheConfigHolder) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.NearCacheConfigHolderCodec
 
encode(ClientMessage, NearCachePreloaderConfig) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.NearCachePreloaderConfigCodec
 
encode(ClientMessage, PredicateConfigHolder) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.PredicateConfigHolderCodec
 
encode(ClientMessage, QueryCacheConfigHolder) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.QueryCacheConfigHolderCodec
 
encode(ClientMessage, QueryCacheEventData) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.QueryCacheEventDataCodec
 
encode(ClientMessage, QueueStoreConfigHolder) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.QueueStoreConfigHolderCodec
 
encode(ClientMessage, RaftGroupId) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.RaftGroupIdCodec
 
encode(ClientMessage, RingbufferStoreConfigHolder) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.RingbufferStoreConfigHolderCodec
 
encode(ClientMessage, ScheduledTaskHandler) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.ScheduledTaskHandlerCodec
 
encode(ClientMessage, SimpleEntryView<Data, Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.SimpleEntryViewCodec
 
encode(ClientMessage, StackTraceElement) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.StackTraceElementCodec
 
encode(ClientMessage, CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.TimedExpiryPolicyFactoryConfigCodec
 
encode(ClientMessage, WanReplicationRef) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.WanReplicationRefCodec
 
encode(ClientMessage, Xid) - Static method in class com.hazelcast.client.impl.protocol.codec.custom.XidCodec
 
encode(byte[]) - Method in enum com.hazelcast.config.security.TokenEncoding
 
encodeAddRequest(boolean) - Method in interface com.hazelcast.client.impl.spi.impl.ListenerMessageCodec
 
encodeAuth(byte, Address, UUID, byte, int, UUID) - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
 
encodeAuth(byte, Address, UUID, byte, int, UUID) - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
 
encodeAuth(byte, Address, UUID, byte, int, UUID) - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationMessageTask
 
encodeBackupEvent(long) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientLocalBackupListenerCodec
 
encodeBatchInvalidation(String, List<Data>, List<UUID>, List<UUID>, List<Long>) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.AbstractBaseNearCacheInvalidationListener
 
encodeBoolean(byte[], int, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
encodeByte(byte[], int, byte) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
encodeCacheBatchInvalidationEvent(String, Collection<Data>, Collection<UUID>, Collection<UUID>, Collection<Long>) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddInvalidationListenerCodec
 
encodeCacheBatchInvalidationEvent(String, Collection<Data>, Collection<UUID>, Collection<UUID>, Collection<Long>) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddNearCacheInvalidationListenerCodec
 
encodeCacheEvent(int, Collection<CacheEventData>, int) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddEntryListenerCodec
 
encodeCacheInvalidationEvent(String, Data, UUID, UUID, long) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddInvalidationListenerCodec
 
encodeCacheInvalidationEvent(String, Data, UUID, UUID, long) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddNearCacheInvalidationListenerCodec
 
encodeCachePartitionLostEvent(int, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddPartitionLostListenerCodec
 
encodeContainsNullable(ClientMessage, Collection<T>, BiConsumer<ClientMessage, T>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ListMultiFrameCodec
 
encodeDistributedObjectEvent(String, String, String) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddDistributedObjectListenerCodec
 
encodeEntryEvent(Data, Data, Data, Data, int, UUID, int) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerCodec
 
encodeEntryEvent(Data, Data, Data, Data, int, UUID, int) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyCodec
 
encodeEntryEvent(Data, Data, Data, Data, int, UUID, int) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyWithPredicateCodec
 
encodeEntryEvent(Data, Data, Data, Data, int, UUID, int) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerWithPredicateCodec
 
encodeEntryEvent(Data, Data, Data, Data, int, UUID, int) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerCodec
 
encodeEntryEvent(Data, Data, Data, Data, int, UUID, int) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerToKeyCodec
 
encodeEntryEvent(Data, Data, Data, Data, int, UUID, int) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerCodec
 
encodeEntryEvent(Data, Data, Data, Data, int, UUID, int) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyCodec
 
encodeEntryEvent(Data, Data, Data, Data, int, UUID, int) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyWithPredicateCodec
 
encodeEntryEvent(Data, Data, Data, Data, int, UUID, int) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerWithPredicateCodec
 
encodeEntryEvent(Data, Data, Data, Data, int, UUID, int) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddNearCacheEntryListenerCodec
 
encodeEnum(byte[], int, CacheEventType) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
encodeEnum(byte[], int, IndexType) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
encodeEnum(byte[], int, CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
encodeEnum(byte[], int, TimeUnit) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
encodeEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapAddEntryListenerMessageTask
 
encodeEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerMessageTask
 
encodeEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyMessageTask
 
encodeEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyWithPredicateMessageTask
 
encodeEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerWithPredicateMessageTask
 
encodeEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddNearCacheInvalidationListenerMessageTask
 
encodeEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.task.map.Pre38MapAddNearCacheEntryListenerMessageTask
 
encodeEvent(Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.task.multimap.AbstractMultiMapAddEntryListenerMessageTask
 
encodeEvent(Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerMessageTask
 
encodeEvent(Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerToKeyMessageTask
 
encodeEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
 
encodeEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
 
encodeEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
 
encodeEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
 
encodeEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
 
encodeEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
 
encodeIMapBatchInvalidationEvent(Collection<Data>, Collection<UUID>, Collection<UUID>, Collection<Long>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheEntryListenerCodec
 
encodeIMapBatchInvalidationEvent(Collection<Data>, Collection<UUID>, Collection<UUID>, Collection<Long>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheInvalidationListenerCodec
 
encodeIMapInvalidationEvent(Data, UUID, UUID, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheEntryListenerCodec
 
encodeIMapInvalidationEvent(Data, UUID, UUID, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheInvalidationListenerCodec
 
encodeInt(byte[], int, int) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
encodeInteger(byte[], int, Integer) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
encodeItemEvent(Data, UUID, int) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddListenerCodec
 
encodeItemEvent(Data, UUID, int) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueAddListenerCodec
 
encodeItemEvent(Data, UUID, int) - Static method in class com.hazelcast.client.impl.protocol.codec.SetAddListenerCodec
 
encodeLong(byte[], int, long) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
encodeMapPartitionLostEvent(int, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddPartitionLostListenerCodec
 
encodeMemberAttributeChangeEvent(Member, Collection<Member>, String, int, String) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddMembershipListenerCodec
 
encodeMemberEvent(Member, int) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddMembershipListenerCodec
 
encodeMemberListEvent(Collection<Member>) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddMembershipListenerCodec
 
encodeNullable(ClientMessage, T, BiConsumer<ClientMessage, T>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.CodecUtil
 
encodeNullable(ClientMessage, Collection<Map.Entry<K, V>>, BiConsumer<ClientMessage, K>, BiConsumer<ClientMessage, V>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.EntryListCodec
 
encodeNullable(ClientMessage, Collection<T>, BiConsumer<ClientMessage, T>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.ListMultiFrameCodec
 
encodeNullable(ClientMessage, Map<K, V>, BiConsumer<ClientMessage, K>, BiConsumer<ClientMessage, V>) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.MapCodec
 
encodePartitionLostEvent(int, int, Address) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionLostListenerCodec
 
encodePartitionsEvent(Collection<Map.Entry<Address, List<Integer>>>, int) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionListenerCodec
 
encodeQueryCacheBatchEvent(Collection<QueryCacheEventData>, String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryAddListenerCodec
 
encodeQueryCacheSingleEvent(QueryCacheEventData) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryAddListenerCodec
 
encodeRemoveRequest(UUID) - Method in interface com.hazelcast.client.impl.spi.impl.ListenerMessageCodec
 
encodeRequest(RaftGroupId, String, long) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongAddAndGetCodec
 
encodeRequest(RaftGroupId, String, Data, int) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongAlterCodec
 
encodeRequest(RaftGroupId, String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongApplyCodec
 
encodeRequest(RaftGroupId, String, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongCompareAndSetCodec
 
encodeRequest(RaftGroupId, String, long) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndAddCodec
 
encodeRequest(RaftGroupId, String, long) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndSetCodec
 
encodeRequest(RaftGroupId, String) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetCodec
 
encodeRequest(RaftGroupId, String, Data, int, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefApplyCodec
 
encodeRequest(RaftGroupId, String, Data, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefCompareAndSetCodec
 
encodeRequest(RaftGroupId, String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefContainsCodec
 
encodeRequest(RaftGroupId, String) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefGetCodec
 
encodeRequest(RaftGroupId, String, Data, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefSetCodec
 
encodeRequest(String, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddEntryListenerCodec
 
encodeRequest(String, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddInvalidationListenerCodec
 
encodeRequest(String, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddNearCacheInvalidationListenerCodec
 
encodeRequest(String, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddPartitionLostListenerCodec
 
encodeRequest() - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAssignAndGetUuidsCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheClearCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheContainsKeyCodec
 
encodeRequest(CacheConfigHolder, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheCreateConfigCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheDestroyCodec
 
encodeRequest(String, Data, Data, Collection<Data>, int) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheEntryProcessorCodec
 
encodeRequest(String, long, int, int, Data, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalReadCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalSubscribeCodec
 
encodeRequest(Collection<String>, Address) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheFetchNearCacheInvalidationMetadataCodec
 
encodeRequest(String, Collection<Data>, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetAllCodec
 
encodeRequest(String, Data, int) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetAndRemoveCodec
 
encodeRequest(String, Data, Data, Data, int) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetAndReplaceCodec
 
encodeRequest(String, Data, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetCodec
 
encodeRequest(String, String) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetConfigCodec
 
encodeRequest(String, int, int) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheIterateCodec
 
encodeRequest(String, int, int) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheIterateEntriesCodec
 
encodeRequest(String, Data, boolean, Address) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheListenerRegistrationCodec
 
encodeRequest(String, Collection<Data>, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheLoadAllCodec
 
encodeRequest(String, boolean, boolean, Address) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheManagementConfigCodec
 
encodeRequest(String, Collection<Map.Entry<Data, Data>>, Data, int) - Static method in class com.hazelcast.client.impl.protocol.codec.CachePutAllCodec
 
encodeRequest(String, Data, Data, Data, boolean, int) - Static method in class com.hazelcast.client.impl.protocol.codec.CachePutCodec
 
encodeRequest(String, Data, Data, Data, int) - Static method in class com.hazelcast.client.impl.protocol.codec.CachePutIfAbsentCodec
 
encodeRequest(String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllCodec
 
encodeRequest(String, Collection<Data>, int) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllKeysCodec
 
encodeRequest(String, Data, Data, int) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveCodec
 
encodeRequest(String, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveEntryListenerCodec
 
encodeRequest(String, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveInvalidationListenerCodec
 
encodeRequest(String, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemovePartitionLostListenerCodec
 
encodeRequest(String, Data, Data, Data, Data, int) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheReplaceCodec
 
encodeRequest(String, Collection<Data>, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheSetExpiryPolicyCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheSizeCodec
 
encodeRequest(String, long) - Static method in class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorAddCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorEstimateCodec
 
encodeRequest(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddDistributedObjectListenerCodec
 
encodeRequest(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddMembershipListenerCodec
 
encodeRequest() - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionListenerCodec
 
encodeRequest(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionLostListenerCodec
 
encodeRequest(String, String, UUID, String, byte, String, String, Collection<String>, int, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec
 
encodeRequest(Data, UUID, String, byte, String, String, Collection<String>, int, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec
 
encodeRequest(Collection<Map.Entry<String, String>>) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientCreateProxiesCodec
 
encodeRequest(String, String, Address) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientCreateProxyCodec
 
encodeRequest(Collection<Map.Entry<String, byte[]>>) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientDeployClassesCodec
 
encodeRequest(String, String) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientDestroyProxyCodec
 
encodeRequest() - Static method in class com.hazelcast.client.impl.protocol.codec.ClientGetDistributedObjectsCodec
 
encodeRequest() - Static method in class com.hazelcast.client.impl.protocol.codec.ClientGetPartitionsCodec
 
encodeRequest() - Static method in class com.hazelcast.client.impl.protocol.codec.ClientIsFailoverSupportedCodec
 
encodeRequest() - Static method in class com.hazelcast.client.impl.protocol.codec.ClientLocalBackupListenerCodec
 
encodeRequest() - Static method in class com.hazelcast.client.impl.protocol.codec.ClientPingCodec
 
encodeRequest() - Static method in class com.hazelcast.client.impl.protocol.codec.ClientRemoveAllListenersCodec
 
encodeRequest(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientRemoveDistributedObjectListenerCodec
 
encodeRequest(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientRemovePartitionLostListenerCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientStatisticsCodec
 
encodeRequest(String, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryAddListenerCodec
 
encodeRequest(String, String) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryDestroyCacheCodec
 
encodeRequest(String, String) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryMadePublishableCodec
 
encodeRequest(String, String, Data, int, int, long, boolean, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateCodec
 
encodeRequest(String, String, Data, int, int, long, boolean, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateWithValueCodec
 
encodeRequest(String, String, long) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQuerySetReadCursorCodec
 
encodeRequest(RaftGroupId, String, UUID, long) - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchAwaitCodec
 
encodeRequest(RaftGroupId, String, UUID, int) - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchCountDownCodec
 
encodeRequest(RaftGroupId, String) - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetCountCodec
 
encodeRequest(RaftGroupId, String) - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetRoundCodec
 
encodeRequest(RaftGroupId, String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchTrySetCountCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.CPGroupCreateCPGroupCodec
 
encodeRequest(RaftGroupId, String, String) - Static method in class com.hazelcast.client.impl.protocol.codec.CPGroupDestroyCPObjectCodec
 
encodeRequest(RaftGroupId, long) - Static method in class com.hazelcast.client.impl.protocol.codec.CPSessionCloseSessionCodec
 
encodeRequest(RaftGroupId, String) - Static method in class com.hazelcast.client.impl.protocol.codec.CPSessionCreateSessionCodec
 
encodeRequest(RaftGroupId) - Static method in class com.hazelcast.client.impl.protocol.codec.CPSessionGenerateThreadIdCodec
 
encodeRequest(RaftGroupId, long) - Static method in class com.hazelcast.client.impl.protocol.codec.CPSessionHeartbeatSessionCodec
 
encodeRequest(String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorDisposeResultCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorIsShutdownCodec
 
encodeRequest(String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveAndDisposeResultCodec
 
encodeRequest(String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveResultCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorShutdownCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorSubmitToPartitionCodec
 
encodeRequest(String, String, String, boolean, boolean, boolean, boolean, String, String, String, String, int, int, String, String, String, boolean, Collection<ListenerConfigHolder>, String, CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig, Collection<CacheSimpleEntryListenerConfig>, EvictionConfigHolder, WanReplicationRef, EventJournalConfig, HotRestartConfig) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec
 
encodeRequest(String, int, int, String, String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCardinalityEstimatorConfigCodec
 
encodeRequest(String, int, int, int, String) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddDurableExecutorConfigCodec
 
encodeRequest(String, int, int, boolean, String) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddExecutorConfigCodec
 
encodeRequest(String, int, long, long, boolean, long) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddFlakeIdGeneratorConfigCodec
 
encodeRequest(String, Collection<ListenerConfigHolder>, int, int, int, boolean, String, String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddListConfigCodec
 
encodeRequest(String, int, int, int, int, String, boolean, String, String, String, Collection<ListenerConfigHolder>, Collection<ListenerConfigHolder>, boolean, String, Data, String, int, MapStoreConfigHolder, NearCacheConfigHolder, WanReplicationRef, Collection<IndexConfig>, Collection<AttributeConfig>, Collection<QueryCacheConfigHolder>, String, Data, HotRestartConfig, EventJournalConfig, MerkleTreeConfig, int, int) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec
 
encodeRequest(String, String, Collection<ListenerConfigHolder>, boolean, int, int, boolean, String, String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMultiMapConfigCodec
 
encodeRequest(String, int, boolean, String) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddPNCounterConfigCodec
 
encodeRequest(String, Collection<ListenerConfigHolder>, int, int, int, int, boolean, String, QueueStoreConfigHolder, String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddQueueConfigCodec
 
encodeRequest(String, Collection<ListenerConfigHolder>, int, boolean, String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReliableTopicConfigCodec
 
encodeRequest(String, String, boolean, boolean, String, Collection<ListenerConfigHolder>, String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReplicatedMapConfigCodec
 
encodeRequest(String, int, int, int, int, String, RingbufferStoreConfigHolder, String, String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddRingbufferConfigCodec
 
encodeRequest(String, int, int, int, String, String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddScheduledExecutorConfigCodec
 
encodeRequest(String, Collection<ListenerConfigHolder>, int, int, int, boolean, String, String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddSetConfigCodec
 
encodeRequest(String, boolean, boolean, boolean, Collection<ListenerConfigHolder>) - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddTopicConfigCodec
 
encodeRequest(UUID, Address, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnAddressCodec
 
encodeRequest(UUID, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnPartitionCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceIsShutdownCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceShutdownCodec
 
encodeRequest(String, UUID, Data, Address) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToAddressCodec
 
encodeRequest(String, UUID, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToPartitionCodec
 
encodeRequest(RaftGroupId, String) - Static method in class com.hazelcast.client.impl.protocol.codec.FencedLockGetLockOwnershipCodec
 
encodeRequest(RaftGroupId, String, long, long, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.FencedLockLockCodec
 
encodeRequest(RaftGroupId, String, long, long, UUID, long) - Static method in class com.hazelcast.client.impl.protocol.codec.FencedLockTryLockCodec
 
encodeRequest(RaftGroupId, String, long, long, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.FencedLockUnlockCodec
 
encodeRequest(String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.FlakeIdGeneratorNewIdBatchCodec
 
encodeRequest(String, Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddAllCodec
 
encodeRequest(String, int, Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddAllWithIndexCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddCodec
 
encodeRequest(String, boolean, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddListenerCodec
 
encodeRequest(String, int, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddWithIndexCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.ListClearCodec
 
encodeRequest(String, Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.ListCompareAndRemoveAllCodec
 
encodeRequest(String, Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.ListCompareAndRetainAllCodec
 
encodeRequest(String, Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.ListContainsAllCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ListContainsCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.ListGetAllCodec
 
encodeRequest(String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.ListGetCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ListIndexOfCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.ListIsEmptyCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.ListIteratorCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ListLastIndexOfCodec
 
encodeRequest(String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.ListListIteratorCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ListRemoveCodec
 
encodeRequest(String, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.ListRemoveListenerCodec
 
encodeRequest(String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.ListRemoveWithIndexCodec
 
encodeRequest(String, int, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ListSetCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.ListSizeCodec
 
encodeRequest(String, int, int) - Static method in class com.hazelcast.client.impl.protocol.codec.ListSubCodec
 
encodeRequest(String, boolean, int, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerCodec
 
encodeRequest(String, Data, boolean, int, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyCodec
 
encodeRequest(String, Data, Data, boolean, int, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyWithPredicateCodec
 
encodeRequest(String, Data, boolean, int, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerWithPredicateCodec
 
encodeRequest(String, IndexConfig) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddIndexCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddInterceptorCodec
 
encodeRequest(String, int, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheEntryListenerCodec
 
encodeRequest(String, int, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheInvalidationListenerCodec
 
encodeRequest(String, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddPartitionLostListenerCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAggregateCodec
 
encodeRequest(String, Data, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAggregateWithPredicateCodec
 
encodeRequest() - Static method in class com.hazelcast.client.impl.protocol.codec.MapAssignAndGetUuidsCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.MapClearCodec
 
encodeRequest(String, Address) - Static method in class com.hazelcast.client.impl.protocol.codec.MapClearNearCacheCodec
 
encodeRequest(String, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapContainsKeyCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapContainsValueCodec
 
encodeRequest(String, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapDeleteCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPagingPredicateCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPredicateCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEntrySetCodec
 
encodeRequest(String, long, int, int, Data, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEventJournalReadCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEventJournalSubscribeCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEvictAllCodec
 
encodeRequest(String, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEvictCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnAllKeysCodec
 
encodeRequest(String, Data, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeyCodec
 
encodeRequest(String, Data, Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeysCodec
 
encodeRequest(String, Data, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapExecuteWithPredicateCodec
 
encodeRequest(String, int, int) - Static method in class com.hazelcast.client.impl.protocol.codec.MapFetchEntriesCodec
 
encodeRequest(String, int, int) - Static method in class com.hazelcast.client.impl.protocol.codec.MapFetchKeysCodec
 
encodeRequest(Collection<String>, Address) - Static method in class com.hazelcast.client.impl.protocol.codec.MapFetchNearCacheInvalidationMetadataCodec
 
encodeRequest(String, int, int, Data, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapFetchWithQueryCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.MapFlushCodec
 
encodeRequest(String, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapForceUnlockCodec
 
encodeRequest(String, Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapGetAllCodec
 
encodeRequest(String, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapGetCodec
 
encodeRequest(String, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapGetEntryViewCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.MapIsEmptyCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapIsLockedCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.MapKeySetCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPagingPredicateCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPredicateCodec
 
encodeRequest(String, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapLoadAllCodec
 
encodeRequest(String, Collection<Data>, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapLoadGivenKeysCodec
 
encodeRequest(String, Data, long, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapLockCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapProjectCodec
 
encodeRequest(String, Data, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapProjectWithPredicateCodec
 
encodeRequest(String, Collection<Map.Entry<Data, Data>>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutAllCodec
 
encodeRequest(String, Data, Data, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutCodec
 
encodeRequest(String, Data, Data, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentCodec
 
encodeRequest(String, Data, Data, long, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentWithMaxIdleCodec
 
encodeRequest(String, Data, Data, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutTransientCodec
 
encodeRequest(String, Data, Data, long, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutTransientWithMaxIdleCodec
 
encodeRequest(String, Data, Data, long, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutWithMaxIdleCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveAllCodec
 
encodeRequest(String, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveCodec
 
encodeRequest(String, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveEntryListenerCodec
 
encodeRequest(String, Data, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveIfSameCodec
 
encodeRequest(String, String) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveInterceptorCodec
 
encodeRequest(String, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemovePartitionLostListenerCodec
 
encodeRequest(String, Data, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapReplaceCodec
 
encodeRequest(String, Data, Data, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapReplaceIfSameCodec
 
encodeRequest(String, Data, Data, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapSetCodec
 
encodeRequest(String, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapSetTtlCodec
 
encodeRequest(String, Data, Data, long, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapSetWithMaxIdleCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.MapSizeCodec
 
encodeRequest(String, Data, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapSubmitToKeyCodec
 
encodeRequest(String, Data, long, long, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapTryLockCodec
 
encodeRequest(String, Data, Data, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapTryPutCodec
 
encodeRequest(String, Data, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapTryRemoveCodec
 
encodeRequest(String, Data, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapUnlockCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.MapValuesCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapValuesWithPagingPredicateCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapValuesWithPredicateCodec
 
encodeRequest(UUID, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MetricsReadMetricsCodec
 
encodeRequest(String, boolean, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerCodec
 
encodeRequest(String, Data, boolean, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerToKeyCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapClearCodec
 
encodeRequest(String, Data, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsEntryCodec
 
encodeRequest(String, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsKeyCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsValueCodec
 
encodeRequest(String, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapDeleteCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapEntrySetCodec
 
encodeRequest(String, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapForceUnlockCodec
 
encodeRequest(String, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapGetCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapIsLockedCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapKeySetCodec
 
encodeRequest(String, Data, long, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapLockCodec
 
encodeRequest(String, Data, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapPutCodec
 
encodeRequest(String, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveCodec
 
encodeRequest(String, Data, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryCodec
 
encodeRequest(String, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryListenerCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapSizeCodec
 
encodeRequest(String, Data, long, long, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapTryLockCodec
 
encodeRequest(String, Data, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapUnlockCodec
 
encodeRequest(String, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapValueCountCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapValuesCodec
 
encodeRequest(String, long, boolean, Collection<Map.Entry<UUID, Long>>, Address) - Static method in class com.hazelcast.client.impl.protocol.codec.PNCounterAddCodec
 
encodeRequest(String, Collection<Map.Entry<UUID, Long>>, Address) - Static method in class com.hazelcast.client.impl.protocol.codec.PNCounterGetCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.PNCounterGetConfiguredReplicaCountCodec
 
encodeRequest(String, Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueAddAllCodec
 
encodeRequest(String, boolean, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueAddListenerCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueClearCodec
 
encodeRequest(String, Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRemoveAllCodec
 
encodeRequest(String, Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRetainAllCodec
 
encodeRequest(String, Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueContainsAllCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueContainsCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueDrainToCodec
 
encodeRequest(String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueDrainToMaxSizeCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueIsEmptyCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueIteratorCodec
 
encodeRequest(String, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueOfferCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.QueuePeekCodec
 
encodeRequest(String, long) - Static method in class com.hazelcast.client.impl.protocol.codec.QueuePollCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.QueuePutCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueRemainingCapacityCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueRemoveCodec
 
encodeRequest(String, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueRemoveListenerCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueSizeCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueTakeCodec
 
encodeRequest(String, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerCodec
 
encodeRequest(String, Data, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyCodec
 
encodeRequest(String, Data, Data, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyWithPredicateCodec
 
encodeRequest(String, Data, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerWithPredicateCodec
 
encodeRequest(String, boolean, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddNearCacheEntryListenerCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapClearCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsKeyCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsValueCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapEntrySetCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapGetCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapIsEmptyCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapKeySetCodec
 
encodeRequest(String, Collection<Map.Entry<Data, Data>>) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutAllCodec
 
encodeRequest(String, Data, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveCodec
 
encodeRequest(String, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveEntryListenerCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapSizeCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapValuesCodec
 
encodeRequest(String, Collection<Data>, int) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferAddAllCodec
 
encodeRequest(String, int, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferAddCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferCapacityCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferHeadSequenceCodec
 
encodeRequest(String, long, int, int, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferReadManyCodec
 
encodeRequest(String, long) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferReadOneCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferRemainingCapacityCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferSizeCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferTailSequenceCodec
 
encodeRequest(String, String, Address, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromAddressCodec
 
encodeRequest(String, String, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromPartitionCodec
 
encodeRequest(String, String, Address) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromAddressCodec
 
encodeRequest(String, String) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromPartitionCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetAllScheduledFuturesCodec
 
encodeRequest(String, String, Address) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromAddressCodec
 
encodeRequest(String, String) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromPartitionCodec
 
encodeRequest(String, String, Address) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromAddressCodec
 
encodeRequest(String, String) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromPartitionCodec
 
encodeRequest(String, String, Address) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromAddressCodec
 
encodeRequest(String, String) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromPartitionCodec
 
encodeRequest(String, String, Address) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromAddressCodec
 
encodeRequest(String, String) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromPartitionCodec
 
encodeRequest(String, String, Address) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromAddressCodec
 
encodeRequest(String, String) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromPartitionCodec
 
encodeRequest(String, Address) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorShutdownCodec
 
encodeRequest(String, Address, byte, String, Data, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToAddressCodec
 
encodeRequest(String, byte, String, Data, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToPartitionCodec
 
encodeRequest(RaftGroupId, String, long, long, UUID, int, long) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreAcquireCodec
 
encodeRequest(RaftGroupId, String) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreAvailablePermitsCodec
 
encodeRequest(RaftGroupId, String, long, long, UUID, int) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreChangeCodec
 
encodeRequest(RaftGroupId, String, long, long, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreDrainCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreGetSemaphoreTypeCodec
 
encodeRequest(RaftGroupId, String, int) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreInitCodec
 
encodeRequest(RaftGroupId, String, long, long, UUID, int) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreReleaseCodec
 
encodeRequest(String, Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.SetAddAllCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.SetAddCodec
 
encodeRequest(String, boolean, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.SetAddListenerCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.SetClearCodec
 
encodeRequest(String, Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.SetCompareAndRemoveAllCodec
 
encodeRequest(String, Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.SetCompareAndRetainAllCodec
 
encodeRequest(String, Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.SetContainsAllCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.SetContainsCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.SetGetAllCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.SetIsEmptyCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.SetRemoveCodec
 
encodeRequest(String, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.SetRemoveListenerCodec
 
encodeRequest(String) - Static method in class com.hazelcast.client.impl.protocol.codec.SetSizeCodec
 
encodeRequest(String, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.TopicAddMessageListenerCodec
 
encodeRequest(String, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TopicPublishCodec
 
encodeRequest(String, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.TopicRemoveMessageListenerCodec
 
encodeRequest(String, UUID, long, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalListAddCodec
 
encodeRequest(String, UUID, long, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalListRemoveCodec
 
encodeRequest(String, UUID, long) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalListSizeCodec
 
encodeRequest(String, UUID, long, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsKeyCodec
 
encodeRequest(String, UUID, long, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsValueCodec
 
encodeRequest(String, UUID, long, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapDeleteCodec
 
encodeRequest(String, UUID, long, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetCodec
 
encodeRequest(String, UUID, long, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetForUpdateCodec
 
encodeRequest(String, UUID, long) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapIsEmptyCodec
 
encodeRequest(String, UUID, long) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetCodec
 
encodeRequest(String, UUID, long, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetWithPredicateCodec
 
encodeRequest(String, UUID, long, Data, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutCodec
 
encodeRequest(String, UUID, long, Data, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutIfAbsentCodec
 
encodeRequest(String, UUID, long, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveCodec
 
encodeRequest(String, UUID, long, Data, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveIfSameCodec
 
encodeRequest(String, UUID, long, Data, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceCodec
 
encodeRequest(String, UUID, long, Data, Data, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceIfSameCodec
 
encodeRequest(String, UUID, long, Data, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSetCodec
 
encodeRequest(String, UUID, long) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSizeCodec
 
encodeRequest(String, UUID, long) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesCodec
 
encodeRequest(String, UUID, long, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesWithPredicateCodec
 
encodeRequest(String, UUID, long, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapGetCodec
 
encodeRequest(String, UUID, long, Data, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapPutCodec
 
encodeRequest(String, UUID, long, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveCodec
 
encodeRequest(String, UUID, long, Data, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveEntryCodec
 
encodeRequest(String, UUID, long) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapSizeCodec
 
encodeRequest(String, UUID, long, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapValueCountCodec
 
encodeRequest(String, UUID, long, Data, long) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueOfferCodec
 
encodeRequest(String, UUID, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePeekCodec
 
encodeRequest(String, UUID, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePollCodec
 
encodeRequest(String, UUID, long) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueSizeCodec
 
encodeRequest(String, UUID, long) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueTakeCodec
 
encodeRequest(String, UUID, long, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalSetAddCodec
 
encodeRequest(String, UUID, long, Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalSetRemoveCodec
 
encodeRequest(String, UUID, long) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalSetSizeCodec
 
encodeRequest(UUID, long) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionCommitCodec
 
encodeRequest(long, int, int, long) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionCreateCodec
 
encodeRequest(UUID, long) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionRollbackCodec
 
encodeRequest(Xid) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionClearRemoteCodec
 
encodeRequest() - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionCollectTransactionsCodec
 
encodeRequest(UUID, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionCommitCodec
 
encodeRequest(Xid, long) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionCreateCodec
 
encodeRequest(Xid, boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionFinalizeCodec
 
encodeRequest(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionPrepareCodec
 
encodeRequest(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionRollbackCodec
 
encodeRequest(String, long) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterAddAndGetCodec
 
encodeRequest(String) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterDecrementAndGetCodec
 
encodeRequest(String, long) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndAddCodec
 
encodeRequest(String) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndIncrementCodec
 
encodeRequest(String, long) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndSetCodec
 
encodeRequest(String) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetCodec
 
encodeRequest(String) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterIncrementAndGetCodec
 
encodeRequest(String, long) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterSetCodec
 
encodeResponse(long) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongAddAndGetCodec
 
encodeResponse(long) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongAlterCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongApplyCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongCompareAndSetCodec
 
encodeResponse(long) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndAddCodec
 
encodeResponse(long) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndSetCodec
 
encodeResponse(long) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefApplyCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefCompareAndSetCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefContainsCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefGetCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.AtomicRefSetCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddEntryListenerCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddInvalidationListenerCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddNearCacheInvalidationListenerCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAddPartitionLostListenerCodec
 
encodeResponse(Collection<Map.Entry<Integer, UUID>>) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheAssignAndGetUuidsCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.CacheClearCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheContainsKeyCodec
 
encodeResponse(CacheConfigHolder) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheCreateConfigCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.CacheDestroyCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheEntryProcessorCodec
 
encodeResponse(int, Collection<Data>, long[], long) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalReadCodec
 
encodeResponse(long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalSubscribeCodec
 
encodeResponse(Collection<Map.Entry<String, List<Map.Entry<Integer, Long>>>>, Collection<Map.Entry<Integer, UUID>>) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheFetchNearCacheInvalidationMetadataCodec
 
encodeResponse(Collection<Map.Entry<Data, Data>>) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetAllCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetAndRemoveCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetAndReplaceCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetCodec
 
encodeResponse(CacheConfigHolder) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheGetConfigCodec
 
encodeResponse(int, Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheIterateCodec
 
encodeResponse(int, Collection<Map.Entry<Data, Data>>) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheIterateEntriesCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.CacheListenerRegistrationCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.CacheLoadAllCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.CacheManagementConfigCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.CachePutAllCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.CachePutCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.CachePutIfAbsentCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllKeysCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveEntryListenerCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemoveInvalidationListenerCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheRemovePartitionLostListenerCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheReplaceCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheSetExpiryPolicyCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheSizeCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorAddCodec
 
encodeResponse(long) - Static method in class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorEstimateCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddDistributedObjectListenerCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddMembershipListenerCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionListenerCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionLostListenerCodec
 
encodeResponse(byte, Address, UUID, byte, String, int, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec
 
encodeResponse(byte, Address, UUID, byte, String, int, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.ClientCreateProxiesCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.ClientCreateProxyCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.ClientDeployClassesCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.ClientDestroyProxyCodec
 
encodeResponse(Collection<DistributedObjectInfo>) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientGetDistributedObjectsCodec
 
encodeResponse(Collection<Map.Entry<Address, List<Integer>>>, int) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientGetPartitionsCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientIsFailoverSupportedCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientLocalBackupListenerCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.ClientPingCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.ClientRemoveAllListenersCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientRemoveDistributedObjectListenerCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ClientRemovePartitionLostListenerCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.ClientStatisticsCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryAddListenerCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryDestroyCacheCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryMadePublishableCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateCodec
 
encodeResponse(Collection<Map.Entry<Data, Data>>) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateWithValueCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ContinuousQuerySetReadCursorCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchAwaitCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchCountDownCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetCountCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetRoundCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.CountDownLatchTrySetCountCodec
 
encodeResponse(RaftGroupId) - Static method in class com.hazelcast.client.impl.protocol.codec.CPGroupCreateCPGroupCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.CPGroupDestroyCPObjectCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.CPSessionCloseSessionCodec
 
encodeResponse(long, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.CPSessionCreateSessionCodec
 
encodeResponse(long) - Static method in class com.hazelcast.client.impl.protocol.codec.CPSessionGenerateThreadIdCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.CPSessionHeartbeatSessionCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorDisposeResultCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorIsShutdownCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveAndDisposeResultCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveResultCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorShutdownCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.DurableExecutorSubmitToPartitionCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCardinalityEstimatorConfigCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddDurableExecutorConfigCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddExecutorConfigCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddFlakeIdGeneratorConfigCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddListConfigCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMultiMapConfigCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddPNCounterConfigCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddQueueConfigCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReliableTopicConfigCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReplicatedMapConfigCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddRingbufferConfigCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddScheduledExecutorConfigCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddSetConfigCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddTopicConfigCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnAddressCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnPartitionCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceIsShutdownCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceShutdownCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToAddressCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToPartitionCodec
 
encodeResponse(long, int, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.FencedLockGetLockOwnershipCodec
 
encodeResponse(long) - Static method in class com.hazelcast.client.impl.protocol.codec.FencedLockLockCodec
 
encodeResponse(long) - Static method in class com.hazelcast.client.impl.protocol.codec.FencedLockTryLockCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.FencedLockUnlockCodec
 
encodeResponse(long, long, int) - Static method in class com.hazelcast.client.impl.protocol.codec.FlakeIdGeneratorNewIdBatchCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddAllCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddAllWithIndexCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddListenerCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.ListAddWithIndexCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.ListClearCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ListCompareAndRemoveAllCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ListCompareAndRetainAllCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ListContainsAllCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ListContainsCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.ListGetAllCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ListGetCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.ListIndexOfCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ListIsEmptyCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.ListIteratorCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.ListLastIndexOfCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.ListListIteratorCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ListRemoveCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ListRemoveListenerCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ListRemoveWithIndexCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ListSetCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.ListSizeCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.ListSubCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyWithPredicateCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerWithPredicateCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddIndexCodec
 
encodeResponse(String) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddInterceptorCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheEntryListenerCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheInvalidationListenerCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAddPartitionLostListenerCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAggregateCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAggregateWithPredicateCodec
 
encodeResponse(Collection<Map.Entry<Integer, UUID>>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapAssignAndGetUuidsCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MapClearCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MapClearNearCacheCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapContainsKeyCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapContainsValueCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MapDeleteCodec
 
encodeResponse(Collection<Map.Entry<Data, Data>>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPagingPredicateCodec
 
encodeResponse(Collection<Map.Entry<Data, Data>>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPredicateCodec
 
encodeResponse(Collection<Map.Entry<Data, Data>>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEntrySetCodec
 
encodeResponse(int, Collection<Data>, long[], long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEventJournalReadCodec
 
encodeResponse(long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEventJournalSubscribeCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MapEvictAllCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapEvictCodec
 
encodeResponse(Collection<Map.Entry<Data, Data>>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnAllKeysCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeyCodec
 
encodeResponse(Collection<Map.Entry<Data, Data>>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeysCodec
 
encodeResponse(Collection<Map.Entry<Data, Data>>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapExecuteWithPredicateCodec
 
encodeResponse(int, Collection<Map.Entry<Data, Data>>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapFetchEntriesCodec
 
encodeResponse(int, Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapFetchKeysCodec
 
encodeResponse(Collection<Map.Entry<String, List<Map.Entry<Integer, Long>>>>, Collection<Map.Entry<Integer, UUID>>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapFetchNearCacheInvalidationMetadataCodec
 
encodeResponse(Collection<Data>, int) - Static method in class com.hazelcast.client.impl.protocol.codec.MapFetchWithQueryCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MapFlushCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MapForceUnlockCodec
 
encodeResponse(Collection<Map.Entry<Data, Data>>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapGetAllCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapGetCodec
 
encodeResponse(SimpleEntryView<Data, Data>, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MapGetEntryViewCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapIsEmptyCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapIsLockedCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapKeySetCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPagingPredicateCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPredicateCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MapLoadAllCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MapLoadGivenKeysCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MapLockCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapProjectCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapProjectWithPredicateCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutAllCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentWithMaxIdleCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutTransientCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutTransientWithMaxIdleCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapPutWithMaxIdleCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveAllCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveEntryListenerCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveIfSameCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemoveInterceptorCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapRemovePartitionLostListenerCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapReplaceCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapReplaceIfSameCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MapSetCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapSetTtlCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapSetWithMaxIdleCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.MapSizeCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.MapSubmitToKeyCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapTryLockCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapTryPutCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MapTryRemoveCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MapUnlockCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapValuesCodec
 
encodeResponse(Collection<Map.Entry<Data, Data>>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapValuesWithPagingPredicateCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.MapValuesWithPredicateCodec
 
encodeResponse(Collection<Map.Entry<Long, byte[]>>, long) - Static method in class com.hazelcast.client.impl.protocol.codec.MetricsReadMetricsCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerToKeyCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapClearCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsEntryCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsKeyCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsValueCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapDeleteCodec
 
encodeResponse(Collection<Map.Entry<Data, Data>>) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapEntrySetCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapForceUnlockCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapGetCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapIsLockedCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapKeySetCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapLockCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapPutCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryListenerCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapSizeCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapTryLockCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapUnlockCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapValueCountCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.MultiMapValuesCodec
 
encodeResponse(long, Collection<Map.Entry<UUID, Long>>, int) - Static method in class com.hazelcast.client.impl.protocol.codec.PNCounterAddCodec
 
encodeResponse(long, Collection<Map.Entry<UUID, Long>>, int) - Static method in class com.hazelcast.client.impl.protocol.codec.PNCounterGetCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.PNCounterGetConfiguredReplicaCountCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueAddAllCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueAddListenerCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.QueueClearCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRemoveAllCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRetainAllCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueContainsAllCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueContainsCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueDrainToCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueDrainToMaxSizeCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueIsEmptyCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueIteratorCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueOfferCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.QueuePeekCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.QueuePollCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.QueuePutCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueRemainingCapacityCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueRemoveCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueRemoveListenerCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueSizeCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.QueueTakeCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyWithPredicateCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerWithPredicateCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddNearCacheEntryListenerCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapClearCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsKeyCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsValueCodec
 
encodeResponse(Collection<Map.Entry<Data, Data>>) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapEntrySetCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapGetCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapIsEmptyCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapKeySetCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutAllCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveEntryListenerCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapSizeCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapValuesCodec
 
encodeResponse(long) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferAddAllCodec
 
encodeResponse(long) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferAddCodec
 
encodeResponse(long) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferCapacityCodec
 
encodeResponse(long) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferHeadSequenceCodec
 
encodeResponse(int, Collection<Data>, long[], long) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferReadManyCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferReadOneCodec
 
encodeResponse(long) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferRemainingCapacityCodec
 
encodeResponse(long) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferSizeCodec
 
encodeResponse(long) - Static method in class com.hazelcast.client.impl.protocol.codec.RingbufferTailSequenceCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromAddressCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromPartitionCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromAddressCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromPartitionCodec
 
encodeResponse(Collection<Map.Entry<Member, List<ScheduledTaskHandler>>>) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetAllScheduledFuturesCodec
 
encodeResponse(long) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromAddressCodec
 
encodeResponse(long) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromPartitionCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromAddressCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromPartitionCodec
 
encodeResponse(long, long, long, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromAddressCodec
 
encodeResponse(long, long, long, long, long) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromPartitionCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromAddressCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromPartitionCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromAddressCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromPartitionCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorShutdownCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToAddressCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToPartitionCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreAcquireCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreAvailablePermitsCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreChangeCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreDrainCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreGetSemaphoreTypeCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreInitCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.SemaphoreReleaseCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.SetAddAllCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.SetAddCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.SetAddListenerCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.SetClearCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.SetCompareAndRemoveAllCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.SetCompareAndRetainAllCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.SetContainsAllCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.SetContainsCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.SetGetAllCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.SetIsEmptyCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.SetRemoveCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.SetRemoveListenerCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.SetSizeCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.TopicAddMessageListenerCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.TopicPublishCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.TopicRemoveMessageListenerCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalListAddCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalListRemoveCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalListSizeCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsKeyCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsValueCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapDeleteCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetForUpdateCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapIsEmptyCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetWithPredicateCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutIfAbsentCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveIfSameCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceIfSameCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSetCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSizeCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesWithPredicateCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapGetCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapPutCodec
 
encodeResponse(Collection<Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveEntryCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapSizeCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapValueCountCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueOfferCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePeekCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePollCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueSizeCodec
 
encodeResponse(Data) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueTakeCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalSetAddCodec
 
encodeResponse(boolean) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalSetRemoveCodec
 
encodeResponse(int) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionalSetSizeCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionCommitCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionCreateCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.TransactionRollbackCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionClearRemoteCodec
 
encodeResponse(Collection<Xid>) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionCollectTransactionsCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionCommitCodec
 
encodeResponse(UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionCreateCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionFinalizeCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionPrepareCodec
 
encodeResponse() - Static method in class com.hazelcast.client.impl.protocol.codec.XATransactionRollbackCodec
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.AddBackupListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddEntryListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddNearCacheInvalidationListenerTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheContainsKeyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheCreateConfigMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEntryProcessorMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalReadTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalSubscribeTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheFetchNearCacheInvalidationMetadataTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndRemoveMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndReplaceMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetConfigMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateEntriesMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutIfAbsentMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheReplaceMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSetExpiryPolicyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSizeMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cache.Pre38CacheAddInvalidationListenerTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorAddMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorEstimateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ClientStatisticsMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterAddMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetConfiguredReplicaCountMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.CreateProxiesMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.DeployClassesMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddCacheConfigMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddCardinalityEstimatorConfigMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddDurableExecutorConfigMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddExecutorConfigMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddFlakeIdGeneratorConfigMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddListConfigMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddMapConfigMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddMultiMapConfigMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddQueueConfigMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddReliableTopicConfigMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddReplicatedMapConfigMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddRingbufferConfigMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddScheduledExecutorConfigMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddSetConfigMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddTopicConfigMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorDisposeResultMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorIsShutdownMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveAndDisposeResultMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveResultMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorShutdownMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorSubmitToPartitionMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnAddressMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnPartitionMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.IsFailoverSupportedMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllWithIndexMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddWithIndexMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListClearMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRemoveAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRetainAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListIndexOfMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListIsEmptyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListIteratorMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListLastIndexOfMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListListIteratorMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveWithIndexMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListSetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListSizeMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.list.ListSubMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyWithPredicateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerWithPredicateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddIndexMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddInterceptorMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddNearCacheInvalidationListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateWithPredicateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsKeyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsValueMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapDeleteMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapDestroyCacheMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPagingPredicateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPredicateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntrySetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEventJournalReadTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEventJournalSubscribeTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnAllKeysMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeysMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteWithPredicateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchEntriesMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchKeysMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchNearCacheInvalidationMetadataTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchWithQueryMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetEntryViewMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapMadePublishableMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionWithPredicateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateWithValueMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentWithMaxIdleMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutTransientMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutTransientWithMaxIdleMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutWithMaxIdleMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveEntryListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveIfSameMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemovePartitionLostListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceIfSameMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetReadCursorMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetTtlMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetWithMaxIdleMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSizeMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSubmitToKeyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryLockMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryPutMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryRemoveMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapUnlockMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPagingPredicateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPredicateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.map.Pre38MapAddNearCacheEntryListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.metrics.ReadMetricsMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerToKeyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapClearMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsEntryMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsKeyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsValueMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapDeleteMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapGetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapPutMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValueCountMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueClearMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRemoveAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRetainAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMaxSizeMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIsEmptyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIteratorMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueOfferMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePeekMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePollMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePutMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemainingCapacityMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueSizeMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueTakeMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferCapacityMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferHeadSequenceMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadManyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadOneMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferRemainingCapacityMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferSizeMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferTailSequenceMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorGetAllScheduledMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorShutdownMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToAddressMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToPartitionMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromAddressMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromPartitionMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromAddressMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromPartitionMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromAddressMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromPartitionMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromAddressMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromPartitionMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromAddressMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromPartitionMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromAddressMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromPartitionMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromAddressMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromPartitionMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetClearMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRemoveAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRetainAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetGetAllMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetIsEmptyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.set.SetSizeMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicAddMessageListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicPublishMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicRemoveMessageListenerMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCommitMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCreateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionRollbackMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAClearRemoteTransactionMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XACollectTransactionsMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAFinalizeTransactionMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCommitMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCreateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionPrepareMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionRollbackMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListAddMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListRemoveMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListSizeMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapContainsKeyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapDeleteMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetForUpdateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapIsEmptyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetWithPredicateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutIfAbsentMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveIfSameMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceIfSameMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSizeMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesWithPredicateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapGetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapPutMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveEntryMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapSizeMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapValueCountMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueOfferMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePeekMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePollMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueSizeMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueTakeMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetAddMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetRemoveMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetSizeMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.AddAndGetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.AlterMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.ApplyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.CompareAndSetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetAndAddMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetAndSetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.ApplyMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.CompareAndSetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.ContainsMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.GetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.SetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.AwaitMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.CountDownMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.GetCountMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.GetRoundMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.TrySetCountMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.lock.client.GetLockOwnershipStateMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.lock.client.LockMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.lock.client.TryLockMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.lock.client.UnlockMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.AcquirePermitsMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.AvailablePermitsMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.ChangePermitsMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.DrainPermitsMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.GetSemaphoreTypeMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.InitSemaphoreMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.ReleasePermitsMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.spi.client.CreateRaftGroupMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.datastructures.spi.client.DestroyRaftObjectMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.session.client.CloseSessionMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.session.client.CreateSessionMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.session.client.GenerateThreadIdMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.cp.internal.session.client.HeartbeatSessionMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.flakeidgen.impl.client.NewIdBatchMessageTask
 
encodeResponse(long) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterAddAndGetCodec
 
encodeResponse(long) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterDecrementAndGetCodec
 
encodeResponse(long) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndAddCodec
 
encodeResponse(long) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndIncrementCodec
 
encodeResponse(long) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndSetCodec
 
encodeResponse(long) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetCodec
 
encodeResponse(long) - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterIncrementAndGetCodec
 
encodeResponse() - Static method in class com.hazelcast.internal.longregister.client.codec.LongRegisterSetCodec
 
encodeResponse(Object) - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterAddAndGetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterDecrementAndGetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndAddMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndIncrementMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndSetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterIncrementAndGetMessageTask
 
encodeResponse(Object) - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterSetMessageTask
 
encodeSingleInvalidation(String, Data, UUID, UUID, long) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.AbstractBaseNearCacheInvalidationListener
 
encodeTopicEvent(Data, long, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.TopicAddMessageListenerCodec
 
encodeUUID(byte[], int, UUID) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
encrypt(String, int) - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
Encrypts given string with key generated from AbstractPbeReplacer.getPassword() with given iteration count and return the masked value (to be used as the variable).
encrypt(String...) - Static method in class com.hazelcast.config.replacer.EncryptionReplacer
 
EncryptionAtRestConfig - Class in com.hazelcast.config
Contains configuration for the Hot Restart Persistence at Rest encryption
EncryptionAtRestConfig() - Constructor for class com.hazelcast.config.EncryptionAtRestConfig
 
EncryptionReplacer - Class in com.hazelcast.config.replacer
This class is an example ConfigReplacer implementation which decrypts encrypted values.
EncryptionReplacer() - Constructor for class com.hazelcast.config.replacer.EncryptionReplacer
 
end(Xid, int) - Method in class com.hazelcast.client.impl.proxy.txn.xa.XAResourceProxy
 
END - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
 
end(Xid, int) - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
 
END_DATA_STRUCTURE_FLAG - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
END_FRAGMENT_FLAG - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
END_FRAME - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
END_SEQUENCE - Static variable in class com.hazelcast.map.impl.querycache.publisher.AccumulatorSweeper
 
endArray(A) - Method in class com.hazelcast.internal.json.JsonHandler
Indicates the end of an array in the JSON input.
endArrayValue(A) - Method in class com.hazelcast.internal.json.JsonHandler
Indicates the end of an array element in the JSON input.
endBoolean(boolean) - Method in class com.hazelcast.internal.json.JsonHandler
Indicates the end of a boolean literal (true or false) in the JSON input.
EndiannessUtil - Class in com.hazelcast.internal.memory.impl
A utility class with methods that read/write multibyte values from/to byte-addressed memory, with explicitly specified endianness.
endNull() - Method in class com.hazelcast.internal.json.JsonHandler
Indicates the end of a null literal in the JSON input.
endNumber(String) - Method in class com.hazelcast.internal.json.JsonHandler
Indicates the end of a number in the JSON input.
endObject(O) - Method in class com.hazelcast.internal.json.JsonHandler
Indicates the end of an object in the JSON input.
endObjectName(O, String) - Method in class com.hazelcast.internal.json.JsonHandler
Indicates the end of an object member name in the JSON input.
endObjectValue(O, String) - Method in class com.hazelcast.internal.json.JsonHandler
Indicates the end of an object member value in the JSON input.
endpoint - Variable in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
Endpoint - Interface in com.hazelcast.cluster
Endpoint represents a peer in the cluster.
endpoint() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.AcquireInvocationKey
 
endpoint() - Method in class com.hazelcast.cp.internal.raft.impl.state.LeadershipTransferState
 
endpoint() - Method in class com.hazelcast.cp.internal.session.CPSessionInfo
 
endpoint() - Method in interface com.hazelcast.cp.session.CPSession
Returns the endpoint that has created this session
ENDPOINT_QUALIFIER - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
EndpointConfig - Class in com.hazelcast.config
Endpoint configuration that defines communication/networking properties common to both incoming/outgoing connections eg.
EndpointConfig() - Constructor for class com.hazelcast.config.EndpointConfig
 
EndpointConnectionLifecycleListener() - Constructor for class com.hazelcast.internal.nio.tcp.TcpIpEndpointManager.EndpointConnectionLifecycleListener
 
EndpointManager<T extends Connection> - Interface in com.hazelcast.internal.nio
Responsible for managing Connection objects.
endpointManager - Variable in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
 
endpointName - Variable in class com.hazelcast.client.impl.protocol.codec.CPSessionCreateSessionCodec.RequestParameters
Name of the caller HazelcastInstance
endpointName() - Method in class com.hazelcast.cp.internal.session.CPSessionInfo
 
endpointName() - Method in interface com.hazelcast.cp.session.CPSession
Returns name of the endpoint that has created this session
EndpointQualifier - Class in com.hazelcast.instance
An EndpointQualifier is a (ProtocolType, String) tuple that uniquely identifies groups of network connections sharing a common ProtocolType and the same network settings, when Hazelcast is configured with AdvancedNetworkConfig enabled.
EndpointQualifier() - Constructor for class com.hazelcast.instance.EndpointQualifier
 
endpointType() - Method in class com.hazelcast.cp.internal.session.CPSessionInfo
 
endpointType() - Method in interface com.hazelcast.cp.session.CPSession
Returns type of the endpoint that has created this session
endSection() - Method in interface com.hazelcast.internal.diagnostics.DiagnosticsLogWriter
 
endSection() - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
endString(String) - Method in class com.hazelcast.internal.json.JsonHandler
Indicates the end of a string in the JSON input.
enqueue(TextCommand) - Method in class com.hazelcast.internal.nio.ascii.TextEncoder
 
enqueueSuspended(TaskDefinition) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
enqueueSuspended(ScheduledTaskDescriptor, boolean) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
ensure(long, int) - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray12byteKey
Ensures that there is a mapping from (key1, key2) to a slot in the array.
ensure(long, long) - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray16byteKey
Ensures that there is a mapping from (key1, key2) to a slot in the array.
ensure(long) - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray8byteKey
Ensures that there is a mapping from the given key to a slot in the array.
ensure(long, int) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray12byteKeyImpl
Ensures that there is a mapping from (key1, key2) to a slot in the array.
ensure(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyImpl
Ensures that there is a mapping from (key1, key2) to a slot in the array.
ensure(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyNoValue
 
ensure(long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray8byteKeyImpl
Ensures that there is a mapping from the given key to a slot in the array.
ensure0(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
ensureBackupLogsExist() - Method in class com.hazelcast.transaction.impl.TransactionImpl
Some data-structures like the Transaction List rely on (empty) backup logs to be created before any change on the data-structure is made.
ensureMember(Address) - Method in class com.hazelcast.spi.impl.operationservice.CallsPerMember
Makes sure that a list of counters is created for a member.
ensureNoSplitBrain(String, SplitBrainProtectionOn) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
ensureNoSplitBrain(String, SplitBrainProtectionOn) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
ensureNoSplitBrain(String, SplitBrainProtectionOn) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
ensureNoSplitBrain(Operation) - Method in class com.hazelcast.splitbrainprotection.impl.SplitBrainProtectionServiceImpl
Ensures that the split brain protection for the given operation is present.
ensureNoSplitBrain(String, SplitBrainProtectionOn) - Method in class com.hazelcast.splitbrainprotection.impl.SplitBrainProtectionServiceImpl
 
ensureNoSplitBrain(String, SplitBrainProtectionOn) - Method in interface com.hazelcast.splitbrainprotection.SplitBrainProtectionService
Ensures that the split brain protection with the given name is present.
ensureOpen() - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
ensureOpen() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
ensurePropertyNotConfigured(HazelcastProperties, HazelcastProperty) - Static method in class com.hazelcast.internal.config.ConfigValidator
Throws InvalidConfigurationException if given group property is defined within Hazelcast properties.
ensureReserve(long) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
ENTERPRISE_CACHE_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ENTERPRISE_CACHE_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ENTERPRISE_HOTRESTART_BACKUP_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ENTERPRISE_HOTRESTART_BACKUP_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ENTERPRISE_HOTRESTART_CLUSTER_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ENTERPRISE_HOTRESTART_CLUSTER_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ENTERPRISE_LICENSE_KEY - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
ENTERPRISE_MAP_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ENTERPRISE_MAP_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ENTERPRISE_MAP_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ENTERPRISE_MAP_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ENTERPRISE_SECURITY_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ENTERPRISE_SECURITY_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ENTERPRISE_WAN_REPLICATION_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ENTERPRISE_WAN_REPLICATION_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
enterpriseOnly(String) - Static method in class com.hazelcast.internal.management.events.AddWanConfigIgnoredEvent
 
enterpriseOnly(String, String, String) - Static method in class com.hazelcast.internal.management.events.WanSyncIgnoredEvent
 
entries - Variable in class com.hazelcast.client.impl.protocol.codec.CacheIterateEntriesCodec.ResponseParameters
TODO DOC
entries - Variable in class com.hazelcast.client.impl.protocol.codec.CachePutAllCodec.RequestParameters
entries to be put as batch
entries - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchEntriesCodec.ResponseParameters
TODO DOC
entries - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutAllCodec.RequestParameters
mappings to be stored in this map
entries - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutAllCodec.RequestParameters
entries to be stored in this map
entries() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendRequest
 
entries() - Method in class com.hazelcast.cp.internal.raft.impl.persistence.RestoredRaftState
 
entries - Variable in class com.hazelcast.internal.management.dto.ClientBwListDTO
 
ENTRIES - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
entries() - Method in class com.hazelcast.map.impl.MapEntries
 
entries() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
 
ENTRIES_WITH_CURSOR - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
entry(K, V) - Static method in class com.hazelcast.internal.util.MapUtil
Returns a Map.Entry with the given key and value.
ENTRY_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
ENTRY_EVENT - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
 
ENTRY_EVENT_FILTER - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
ENTRY_ITERATION_RESULT - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
ENTRY_ITERATOR - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
ENTRY_LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
ENTRY_OFFLOADABLE_SET_UNLOCK - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
ENTRY_OPERATION - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
ENTRY_PROCESSOR - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
ENTRY_PROCESSOR - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
ENTRY_REMOVING_PROCESSOR - Static variable in class com.hazelcast.map.impl.EntryRemovingProcessor
 
ENTRY_REMOVING_PROCESSOR - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
ENTRY_SET - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
ENTRY_SET - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
ENTRY_SET_RESPONSE - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
ENTRY_VIEW - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
ENTRY_VIEW - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
EntryAdapter<K,V> - Class in com.hazelcast.core
Adapter for MapListener.
EntryAdapter() - Constructor for class com.hazelcast.core.EntryAdapter
 
entryAdded(EntryEvent) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
entryAdded(EntryEvent<Object, Object>) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
 
entryAdded(EntryEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
entryAdded(EntryEvent) - Method in class com.hazelcast.console.ConsoleApp
 
entryAdded(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
 
entryAdded(EntryEvent<K, V>) - Method in class com.hazelcast.map.impl.MapListenerAdapter
 
entryAdded(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryAddedListener
Invoked upon addition of an entry.
EntryAddedListener<K,V> - Interface in com.hazelcast.map.listener
Invoked upon addition of an entry.
EntryBackupOperation - Class in com.hazelcast.map.impl.operation
 
EntryBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.EntryBackupOperation
 
EntryBackupOperation(String, Data, EntryProcessor) - Constructor for class com.hazelcast.map.impl.operation.EntryBackupOperation
 
entryBackupProcessor - Variable in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
 
EntryConverter - Class in com.hazelcast.internal.ascii.memcache
Produced MemcacheEntry from key and values
EntryConverter(TextCommandService, ILogger) - Constructor for class com.hazelcast.internal.ascii.memcache.EntryConverter
 
EntryCostEstimator<K,V> - Interface in com.hazelcast.map.impl
Owned entry cost estimator general contract.
entryCount() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendRequest
 
EntryCountCacheEvictionChecker - Class in com.hazelcast.cache.impl.maxsize.impl
Cache max-size policy implementation for EvictionConfig.MaxSizePolicy.ENTRY_COUNT
EntryCountCacheEvictionChecker(int, CacheRecordMap, int) - Constructor for class com.hazelcast.cache.impl.maxsize.impl.EntryCountCacheEvictionChecker
 
EntryCountNearCacheEvictionChecker - Class in com.hazelcast.internal.nearcache.impl.maxsize
Near Cache max-size policy implementation for EvictionConfig.MaxSizePolicy.ENTRY_COUNT.
EntryCountNearCacheEvictionChecker(int, SampleableNearCacheRecordMap) - Constructor for class com.hazelcast.internal.nearcache.impl.maxsize.EntryCountNearCacheEvictionChecker
 
EntryEvent<K,V> - Class in com.hazelcast.core
Map Entry event.
EntryEvent(Object, Member, int, K, V) - Constructor for class com.hazelcast.core.EntryEvent
Constructs an entry event.
EntryEvent(Object, Member, int, K, V, V) - Constructor for class com.hazelcast.core.EntryEvent
Constructs an entry event.
EntryEvent(Object, Member, int, K, V, V, V) - Constructor for class com.hazelcast.core.EntryEvent
Constructs an entry event.
EntryEventData - Class in com.hazelcast.map.impl.event
An entry's event data.
EntryEventData() - Constructor for class com.hazelcast.map.impl.event.EntryEventData
 
EntryEventData(String, String, Address, Data, Data, Data, int) - Constructor for class com.hazelcast.map.impl.event.EntryEventData
 
EntryEventData(String, String, Address, Data, Data, Data, Data, int) - Constructor for class com.hazelcast.map.impl.event.EntryEventData
 
EntryEventDataCache - Interface in com.hazelcast.map.impl.event
A cache for EntryEventData.
EntryEventFilter - Class in com.hazelcast.map.impl
Event filter which matches events for a specified entry key.
EntryEventFilter(boolean, Data) - Constructor for class com.hazelcast.map.impl.EntryEventFilter
 
EntryEventFilter() - Constructor for class com.hazelcast.map.impl.EntryEventFilter
 
EntryEventType - Enum in com.hazelcast.core
Type of entry event.
entryEvicted(EntryEvent) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
entryEvicted(EntryEvent<Object, Object>) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
 
entryEvicted(EntryEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
entryEvicted(EntryEvent) - Method in class com.hazelcast.console.ConsoleApp
 
entryEvicted(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
 
entryEvicted(EntryEvent<K, V>) - Method in class com.hazelcast.map.impl.MapListenerAdapter
 
entryEvicted(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryEvictedListener
Invoked upon eviction of an entry.
EntryEvictedListener<K,V> - Interface in com.hazelcast.map.listener
Invoked upon eviction of an entry.
entryExpired(EntryEvent) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
entryExpired(EntryEvent<Object, Object>) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
 
entryExpired(EntryEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
entryExpired(EntryEvent<Object, Object>) - Method in class com.hazelcast.console.ConsoleApp
 
entryExpired(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
 
entryExpired(EntryEvent<K, V>) - Method in class com.hazelcast.map.impl.MapListenerAdapter
 
entryExpired(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryExpiredListener
Invoked upon expiration of an entry.
EntryExpiredListener<K,V> - Interface in com.hazelcast.map.listener
Listener which is notified after removal of an entry due to the expiration-based-eviction.
entryKey() - Static method in class com.hazelcast.internal.util.function.Functions
Returns a function that extracts the key of a Map.Entry.
EntryListCodec - Class in com.hazelcast.client.impl.protocol.codec.builtin
 
EntryListener<K,V> - Interface in com.hazelcast.core
Map Entry listener to get notified when a map entry is added, removed, updated, evicted or expired.
EntryListenerAdaptors - Class in com.hazelcast.map.impl
Used to support deprecated IMap listener related methods such as IMap.addLocalEntryListener(EntryListener).
EntryListenerConfig - Class in com.hazelcast.config
Configuration for EntryListener
EntryListenerConfig() - Constructor for class com.hazelcast.config.EntryListenerConfig
 
EntryListenerConfig(String, boolean, boolean) - Constructor for class com.hazelcast.config.EntryListenerConfig
 
EntryListenerConfig(EntryListener, boolean, boolean) - Constructor for class com.hazelcast.config.EntryListenerConfig
 
EntryListenerConfig(MapListener, boolean, boolean) - Constructor for class com.hazelcast.config.EntryListenerConfig
 
EntryListenerConfig(EntryListenerConfig) - Constructor for class com.hazelcast.config.EntryListenerConfig
 
EntryListenerConfig.MapListenerToEntryListenerAdapter - Class in com.hazelcast.config
Wraps a MapListener into an EntryListener.
EntryListenerConfigReadOnly - Class in com.hazelcast.internal.config
Configuration for EntryListener(Read Only)
EntryListenerConfigReadOnly(EntryListenerConfig) - Constructor for class com.hazelcast.internal.config.EntryListenerConfigReadOnly
 
EntryListIntegerLongCodec - Class in com.hazelcast.client.impl.protocol.codec.builtin
 
EntryListIntegerUUIDCodec - Class in com.hazelcast.client.impl.protocol.codec.builtin
 
EntryListLongByteArrayCodec - Class in com.hazelcast.client.impl.protocol.codec.builtin
 
EntryListUUIDLongCodec - Class in com.hazelcast.client.impl.protocol.codec.builtin
 
entryLoaded(EntryEvent<K, V>) - Method in class com.hazelcast.map.impl.MapListenerAdapter
 
entryLoaded(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryLoadedListener
Invoked upon load of an entry.
EntryLoadedListener<K,V> - Interface in com.hazelcast.map.listener
Invoked upon load of an entry.
EntryLoader<K,V> - Interface in com.hazelcast.map
This is an extension to MapLoader.
EntryLoader.MetadataAwareValue<V> - Class in com.hazelcast.map
Represents a value with an expiration time attached to it.
entryMerged(EntryEvent<K, V>) - Method in class com.hazelcast.map.impl.MapListenerAdapter
 
entryMerged(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryMergedListener
Invoked after WAN replicated entry is merged.
EntryMergedListener<K,V> - Interface in com.hazelcast.map.listener
Invoked after WAN replicated entry is merged.
EntryOffloadableLockMismatchException - Exception in com.hazelcast.map.impl.operation
Actor of the EntryOffloadableOperation -> EntryOffloadableSetUnlockOperation combined operations flow.
EntryOffloadableLockMismatchException(String) - Constructor for exception com.hazelcast.map.impl.operation.EntryOffloadableLockMismatchException
 
EntryOffloadableSetUnlockOperation - Class in com.hazelcast.map.impl.operation
Set & Unlock processing for the EntryOperation See the javadoc on EntryOperation
EntryOffloadableSetUnlockOperation() - Constructor for class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
 
EntryOffloadableSetUnlockOperation(String, EntryEventType, Data, Data, Data, UUID, long, long, EntryProcessor) - Constructor for class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
 
EntryOperation - Class in com.hazelcast.map.impl.operation
Contains implementation of the off-loadable contract for EntryProcessor execution on a single key.
EntryOperation() - Constructor for class com.hazelcast.map.impl.operation.EntryOperation
 
EntryOperation(String, Data, EntryProcessor) - Constructor for class com.hazelcast.map.impl.operation.EntryOperation
 
EntryOperator - Class in com.hazelcast.map.impl.operation
Operator for single key processing logic of EntryProcessor and backup entry processor related operations.
entryProcessor - Variable in class com.hazelcast.client.impl.protocol.codec.CacheEntryProcessorCodec.RequestParameters
Entry processor to invoke.
entryProcessor - Variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnAllKeysCodec.RequestParameters
entry processor to be executed.
entryProcessor - Variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeyCodec.RequestParameters
processor to execute on the map entry
entryProcessor - Variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeysCodec.RequestParameters
entry processor to be executed.
entryProcessor - Variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteWithPredicateCodec.RequestParameters
entry processor to be executed.
entryProcessor - Variable in class com.hazelcast.client.impl.protocol.codec.MapSubmitToKeyCodec.RequestParameters
entry processor to be executed on the entry.
EntryProcessor<K,V,R> - Interface in com.hazelcast.map
An EntryProcessor passes you a Map.Entry.
entryProcessor - Variable in class com.hazelcast.map.impl.operation.MultipleEntryOperation
 
entryProcessor - Variable in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
 
entryRemoved(EntryEvent) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
entryRemoved(EntryEvent<Object, Object>) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
 
entryRemoved(EntryEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
entryRemoved(EntryEvent) - Method in class com.hazelcast.console.ConsoleApp
 
entryRemoved(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
 
entryRemoved(EntryEvent<K, V>) - Method in class com.hazelcast.map.impl.MapListenerAdapter
 
entryRemoved(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryRemovedListener
Invoked upon removal of an entry.
EntryRemovedListener<K,V> - Interface in com.hazelcast.map.listener
Invoked upon removal of an entry.
EntryRemovingProcessor - Class in com.hazelcast.map.impl
 
EntryRemovingProcessor() - Constructor for class com.hazelcast.map.impl.EntryRemovingProcessor
 
entrySet() - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
entrySet(Predicate) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
entrySet() - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
entrySet() - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
entrySet() - Method in class com.hazelcast.cluster.impl.VectorClock
Returns a set of replica logical timestamps for this vector clock.
entrySet() - Method in class com.hazelcast.internal.dynamicconfig.AggregatingMap
 
entrySet(String) - Method in class com.hazelcast.internal.jmx.MapMBean
 
entrySet() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
entrySet() - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
This set's iterator also implements Map.Entry so the next() method can just return the iterator instance itself with no heap allocation.
entrySet() - Method in class com.hazelcast.internal.util.collection.InternalListMultiMap
 
entrySet() - Method in class com.hazelcast.internal.util.collection.InternalSetMultimap
 
entrySet() - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
This set's iterator also implements Map.Entry so the next() method can just return the iterator instance itself with no heap allocation.
entrySet() - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
This set's iterator also implements Map.Entry so the next() method can just return the iterator instance itself with no heap allocation.
entrySet() - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
Returns a Set view of the mappings contained in this map.
entrySet() - Method in interface com.hazelcast.map.IMap
Returns an immutable Set clone of the mappings contained in this map.
entrySet(Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
Queries the map based on the specified predicate and returns an immutable set of the matching entries.
entrySet() - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
entrySet(Predicate) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
entrySet() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
entrySet(Predicate) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
entrySet() - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordStore
 
entrySet() - Method in interface com.hazelcast.map.QueryCache
 
entrySet(Predicate<K, V>) - Method in interface com.hazelcast.map.QueryCache
 
entrySet() - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
entrySet() - Method in interface com.hazelcast.multimap.MultiMap
Returns the set of key-value pairs in the multimap.
entrySet(boolean) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
entrySet() - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
 
entrySet(boolean) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
entrySet() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
entrySet() - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Returns a lazy Set view of the mappings contained in this map.
A LazySet is optimized for querying speed (preventing eager deserialization and hashing on HashSet insertion) and does NOT provide all operations.
entrySet() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
Intention to expose the entry set is to mutate it.
entrySetInternal() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
EntrySetOperation - Class in com.hazelcast.multimap.impl.operations
 
EntrySetOperation() - Constructor for class com.hazelcast.multimap.impl.operations.EntrySetOperation
 
EntrySetOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.EntrySetOperation
 
EntrySetOperation - Class in com.hazelcast.replicatedmap.impl.operation
 
EntrySetOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.EntrySetOperation
 
EntrySetOperation(String) - Constructor for class com.hazelcast.replicatedmap.impl.operation.EntrySetOperation
 
EntrySetResponse - Class in com.hazelcast.multimap.impl.operations
 
EntrySetResponse() - Constructor for class com.hazelcast.multimap.impl.operations.EntrySetResponse
 
EntrySetResponse(Map<Data, Collection<MultiMapRecord>>, NodeEngine) - Constructor for class com.hazelcast.multimap.impl.operations.EntrySetResponse
 
EntryStore<K,V> - Interface in com.hazelcast.map
This is an extension to MapStore.
EntryTaskScheduler<K,V> - Interface in com.hazelcast.internal.util.scheduler
Schedules (or reschedules) the execution of given entry.
EntryTaskSchedulerFactory - Class in com.hazelcast.internal.util.scheduler
Factory for EntryTaskSchedulers.
entryUpdated(EntryEvent) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
entryUpdated(EntryEvent<Object, Object>) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
 
entryUpdated(EntryEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
entryUpdated(EntryEvent) - Method in class com.hazelcast.console.ConsoleApp
 
entryUpdated(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
 
entryUpdated(EntryEvent<K, V>) - Method in class com.hazelcast.map.impl.MapListenerAdapter
 
entryUpdated(EntryEvent<K, V>) - Method in interface com.hazelcast.map.listener.EntryUpdatedListener
Invoked upon update of an entry.
EntryUpdatedListener<K,V> - Interface in com.hazelcast.map.listener
Invoked upon update of an entry.
entryValue() - Static method in class com.hazelcast.internal.util.function.Functions
Returns a function that extracts the value of a Map.Entry.
EntryView<K,V> - Interface in com.hazelcast.core
Represents a read-only view of a data structure entry.
EntryViews - Class in com.hazelcast.map.impl
A class providing static factory methods that create various entry view objects.
ENUM_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
ENUM_SIZE_IN_BYTES - Static variable in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
EnumSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.EnumSerializer
 
EOF - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
EPOCH_TIME - Static variable in class com.hazelcast.map.impl.record.AbstractRecord
Base time to be used for storing time values as diffs (int) rather than full blown epoch based vals (long) This allows for a space in seconds, of roughly 68 years.
equal(long, long, long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
equal(Comparable, Comparable) - Static method in class com.hazelcast.query.impl.Comparables
Checks the provided Comparable instances for equality.
equal(Number, Number) - Static method in class com.hazelcast.query.impl.Numbers
Checks the provided Number instances for equality.
equal(Comparable) - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
equal(Comparable) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
equal(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates an equal predicate that will pass items if the given value and the value stored under the given item attribute are equal.
EQUAL_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
equalDoubles(double, double) - Static method in class com.hazelcast.query.impl.Numbers
Checks the provided double values for equality exactly as Double.equals(java.lang.Object) does it, avoiding the boxing-unboxing cycle.
equalFloats(float, float) - Static method in class com.hazelcast.query.impl.Numbers
Checks the provided float values for equality exactly as Float.equals(java.lang.Object) does it, avoiding the boxing-unboxing cycle.
equalizeBackupSizeWithPrimary(CachePartitionSegment) - Method in class com.hazelcast.cache.impl.eviction.CacheClearExpiredRecordsTask
 
equalizeBackupSizeWithPrimary(T) - Method in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
equalizeBackupSizeWithPrimary(PartitionContainer) - Method in class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
 
equalLongAndDouble(long, double) - Static method in class com.hazelcast.query.impl.Numbers
Checks the provided long and double values for equality.
EqualPredicate - Class in com.hazelcast.query.impl.predicates
Equal Predicate
EqualPredicate() - Constructor for class com.hazelcast.query.impl.predicates.EqualPredicate
 
EqualPredicate(String) - Constructor for class com.hazelcast.query.impl.predicates.EqualPredicate
 
EqualPredicate(String, Comparable) - Constructor for class com.hazelcast.query.impl.predicates.EqualPredicate
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.AbstractAggregator
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.BigDecimalAverageAggregator
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.BigDecimalSumAggregator
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.BigIntegerAverageAggregator
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.CountAggregator
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.DistinctValuesAggregator
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.DoubleAverageAggregator
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.DoubleSumAggregator
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.FixedSumAggregator
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.FloatingPointSumAggregator
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.IntegerAverageAggregator
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.IntegerSumAggregator
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.LongAverageAggregator
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.LongSumAggregator
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.MaxAggregator
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.MaxByAggregator
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.MinAggregator
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.MinByAggregator
 
equals(Object) - Method in class com.hazelcast.aggregation.impl.NumberAverageAggregator
 
equals(Object) - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
equals(Object) - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
 
equals(Object) - Method in class com.hazelcast.cache.impl.CachePartitionEventData
 
equals(Object) - Method in class com.hazelcast.cache.impl.DeferredValue
 
equals(Object) - Method in class com.hazelcast.cache.impl.event.CachePartitionLostEventFilter
 
equals(Object) - Method in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
 
equals(Object) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
 
equals(Object) - Method in class com.hazelcast.client.config.ClientCloudConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ClientConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
 
equals(Object) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
equals(Object) - Method in class com.hazelcast.client.config.SocketOptions
 
equals(Object) - Method in class com.hazelcast.client.impl.client.DistributedObjectInfo
 
equals(Object) - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
equals(Object) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
equals(Object) - Method in class com.hazelcast.client.impl.protocol.ClientMessage.Frame
 
equals(Object) - Method in class com.hazelcast.client.impl.spi.ClientProxy
 
equals(Object) - Method in class com.hazelcast.client.impl.spi.impl.listener.ClientEventRegistration
 
equals(Object) - Method in class com.hazelcast.client.impl.spi.impl.listener.ClientRegistrationKey
 
equals(Object) - Method in class com.hazelcast.cluster.Address
 
equals(Object) - Method in class com.hazelcast.cluster.impl.AbstractMember
 
equals(Object) - Method in class com.hazelcast.cluster.impl.VectorClock
 
equals(Object) - Method in class com.hazelcast.collection.impl.collection.CollectionEventFilter
 
equals(Object) - Method in class com.hazelcast.collection.impl.collection.CollectionItem
 
equals(Object) - Method in class com.hazelcast.collection.impl.collection.TxCollectionItem
 
equals(Object) - Method in class com.hazelcast.collection.impl.queue.QueueEventFilter
 
equals(Object) - Method in class com.hazelcast.collection.impl.queue.QueueItem
 
equals(Object) - Method in class com.hazelcast.collection.impl.queue.QueueWaitNotifyKey
 
equals(Object) - Method in class com.hazelcast.collection.impl.txnqueue.TxQueueItem
 
equals(Object) - Method in class com.hazelcast.config.AbstractCacheConfig
 
equals(Object) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
 
equals(Object) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
equals(Object) - Method in class com.hazelcast.config.AttributeConfig
 
equals(Object) - Method in class com.hazelcast.config.CacheConfig
 
equals(Object) - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
 
equals(Object) - Method in class com.hazelcast.config.CacheSimpleConfig
 
equals(Object) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
equals(Object) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
equals(Object) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
equals(Object) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
equals(Object) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
equals(Object) - Method in class com.hazelcast.config.ClassFilter
 
equals(Object) - Method in class com.hazelcast.config.CollectionConfig
 
equals(Object) - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
equals(Object) - Method in class com.hazelcast.config.DiscoveryConfig
 
equals(Object) - Method in class com.hazelcast.config.DurableExecutorConfig
 
equals(Object) - Method in class com.hazelcast.config.EncryptionAtRestConfig
 
equals(Object) - Method in class com.hazelcast.config.EntryListenerConfig
 
equals(Object) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
equals(Object) - Method in class com.hazelcast.config.EventJournalConfig
 
equals(Object) - Method in class com.hazelcast.config.EvictionConfig
 
equals(Object) - Method in class com.hazelcast.config.ExecutorConfig
 
equals(Object) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
equals(Object) - Method in class com.hazelcast.config.GlobalSerializerConfig
 
equals(Object) - Method in class com.hazelcast.config.HotRestartConfig
 
equals(Object) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
 
equals(Object) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
equals(Object) - Method in class com.hazelcast.config.IndexConfig
 
equals(Object) - Method in class com.hazelcast.config.InterfacesConfig
 
equals(Object) - Method in class com.hazelcast.config.ItemListenerConfig
 
equals(Object) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
 
equals(Object) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
equals(Object) - Method in class com.hazelcast.config.ListenerConfig
 
equals(Object) - Method in class com.hazelcast.config.LoginModuleConfig
 
equals(Object) - Method in class com.hazelcast.config.MapConfig
 
equals(Object) - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
 
equals(Object) - Method in class com.hazelcast.config.MapStoreConfig
 
equals(Object) - Method in class com.hazelcast.config.matcher.MatchingPointConfigPatternMatcher
 
equals(Object) - Method in class com.hazelcast.config.matcher.RegexConfigPatternMatcher
 
equals(Object) - Method in class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
 
equals(Object) - Method in class com.hazelcast.config.MaxSizeConfig
 
equals(Object) - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
equals(Object) - Method in class com.hazelcast.config.MemberGroupConfig
 
equals(Object) - Method in class com.hazelcast.config.MergePolicyConfig
 
equals(Object) - Method in class com.hazelcast.config.MerkleTreeConfig
 
equals(Object) - Method in class com.hazelcast.config.MetricsConfig
 
equals(Object) - Method in class com.hazelcast.config.MulticastConfig
 
equals(Object) - Method in class com.hazelcast.config.MultiMapConfig
 
equals(Object) - Method in class com.hazelcast.config.NativeMemoryConfig
 
equals(Object) - Method in class com.hazelcast.config.NearCacheConfig
 
equals(Object) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
equals(Object) - Method in class com.hazelcast.config.PartitionGroupConfig
 
equals(Object) - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
equals(Object) - Method in class com.hazelcast.config.PermissionConfig
 
equals(Object) - Method in class com.hazelcast.config.PermissionPolicyConfig
 
equals(Object) - Method in class com.hazelcast.config.PNCounterConfig
 
equals(Object) - Method in class com.hazelcast.config.PredicateConfig
 
equals(Object) - Method in class com.hazelcast.config.QueryCacheConfig
 
equals(Object) - Method in class com.hazelcast.config.QueueConfig
 
equals(Object) - Method in class com.hazelcast.config.QueueStoreConfig
 
equals(Object) - Method in class com.hazelcast.config.ReliableTopicConfig
 
equals(Object) - Method in class com.hazelcast.config.ReplicatedMapConfig
 
equals(Object) - Method in class com.hazelcast.config.RingbufferConfig
 
equals(Object) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
equals(Object) - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
equals(Object) - Method in class com.hazelcast.config.security.CredentialsIdentityConfig
 
equals(Object) - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
 
equals(Object) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
equals(Object) - Method in class com.hazelcast.config.security.RealmConfig
 
equals(Object) - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
 
equals(Object) - Method in class com.hazelcast.config.security.TokenIdentityConfig
 
equals(Object) - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
 
equals(Object) - Method in class com.hazelcast.config.SecurityConfig
 
equals(Object) - Method in class com.hazelcast.config.SerializationConfig
 
equals(Object) - Method in class com.hazelcast.config.SerializerConfig
 
equals(Object) - Method in class com.hazelcast.config.ServiceConfig
 
equals(Object) - Method in class com.hazelcast.config.ServicesConfig
 
equals(Object) - Method in class com.hazelcast.config.SocketInterceptorConfig
 
equals(Object) - Method in class com.hazelcast.config.SSLConfig
 
equals(Object) - Method in class com.hazelcast.config.TcpIpConfig
 
equals(Object) - Method in class com.hazelcast.config.TopicConfig
 
equals(Object) - Method in class com.hazelcast.config.VaultSecureStoreConfig
 
equals(Object) - Method in class com.hazelcast.config.WanConsumerConfig
 
equals(Object) - Method in class com.hazelcast.config.WanReplicationConfig
 
equals(Object) - Method in class com.hazelcast.config.WanReplicationRef
 
equals(Object) - Method in class com.hazelcast.config.WanSyncConfig
 
equals(Object) - Method in class com.hazelcast.core.HazelcastJsonValue
 
equals(Object) - Method in class com.hazelcast.core.LifecycleEvent
 
equals(Object) - Method in class com.hazelcast.cp.internal.CPMemberInfo
 
equals(Object) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.AwaitInvocationKey
 
equals(Object) - Method in class com.hazelcast.cp.internal.datastructures.lock.LockEndpoint
 
equals(Object) - Method in class com.hazelcast.cp.internal.datastructures.lock.LockInvocationKey
 
equals(Object) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.AcquireInvocationKey
 
equals(Object) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreEndpoint
 
equals(Object) - Method in class com.hazelcast.cp.internal.RaftEndpointImpl
 
equals(Object) - Method in class com.hazelcast.cp.internal.RaftGroupId
 
equals(Object) - Method in class com.hazelcast.cp.internal.session.CPSessionInfo
 
equals(Object) - Method in class com.hazelcast.durableexecutor.impl.operations.DurableExecutorWaitNotifyKey
 
equals(Object) - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
equals(Object) - Method in class com.hazelcast.instance.EndpointQualifier
 
equals(Object) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
equals(Object) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
equals(Object) - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
 
equals(Object) - Method in class com.hazelcast.internal.cluster.impl.ClusterStateChange
 
equals(Object) - Method in class com.hazelcast.internal.cluster.impl.MembersViewMetadata
 
equals(Object) - Method in class com.hazelcast.internal.cluster.MemberInfo
 
equals(Object) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
equals(Object) - Method in class com.hazelcast.internal.eviction.EvictionPolicyComparator
 
equals(Object) - Method in class com.hazelcast.internal.json.JsonArray
Indicates whether a given object is "equal to" this JsonArray.
equals(Object) - Method in class com.hazelcast.internal.json.JsonObject
 
equals(Object) - Method in class com.hazelcast.internal.json.JsonObject.Member
Indicates whether a given object is "equal to" this JsonObject.
equals(Object) - Method in class com.hazelcast.internal.json.JsonValue
Indicates whether some other object is "equal to" this one according to the contract specified in Object.equals(Object).
equals(Object) - Method in class com.hazelcast.internal.json.Location
 
equals(Object) - Method in class com.hazelcast.internal.locksupport.LockWaitNotifyKey
 
equals(Object) - Method in class com.hazelcast.internal.networking.ChannelOption
 
equals(Object) - Method in class com.hazelcast.internal.nio.Packet
 
equals(Object) - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
equals(Object) - Method in class com.hazelcast.internal.partition.impl.ReplicaFragmentSyncInfo
 
equals(Object) - Method in class com.hazelcast.internal.partition.MigrationInfo
 
equals(Object) - Method in class com.hazelcast.internal.partition.NonFragmentedServiceNamespace
 
equals(Object) - Method in class com.hazelcast.internal.partition.PartitionReplica
 
equals(Object) - Method in class com.hazelcast.internal.partition.PartitionTableView
 
equals(Object) - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
 
equals(Object) - Method in class com.hazelcast.internal.serialization.impl.FieldDefinitionImpl
 
equals(Object) - Method in class com.hazelcast.internal.serialization.impl.HeapData
 
equals(Object) - Method in class com.hazelcast.internal.services.DistributedObjectNamespace
 
equals(Object) - Method in class com.hazelcast.internal.util.BiTuple
 
equals(Object) - Method in class com.hazelcast.internal.util.collection.IntHashSet
 
equals(Object) - Method in class com.hazelcast.internal.util.collection.LongHashSet
equals(Object) - Method in class com.hazelcast.internal.util.collection.OAHashSet
 
equals(Object) - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap.SimpleEntry
 
equals(Object) - Method in class com.hazelcast.internal.util.ItemCounter
 
equals(Object) - Method in class com.hazelcast.internal.util.MutableLong
 
equals(Object) - Method in class com.hazelcast.internal.util.SampleableConcurrentHashMap.SamplingEntry
 
equals(Object) - Method in class com.hazelcast.internal.util.scheduler.ScheduledEntry
 
equals(Object) - Method in class com.hazelcast.internal.util.TriTuple
 
equals(Object) - Method in class com.hazelcast.json.internal.JsonPattern
 
equals(Object) - Method in class com.hazelcast.json.internal.JsonSchemaNameValue
 
equals(Object) - Method in class com.hazelcast.json.internal.JsonSchemaStructNode
 
equals(Object) - Method in class com.hazelcast.json.internal.JsonSchemaTerminalNode
 
equals(Object) - Method in class com.hazelcast.map.eviction.LFUEvictionPolicy
 
equals(Object) - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
 
equals(Object) - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
 
equals(Object) - Method in class com.hazelcast.map.impl.EntryEventFilter
 
equals(Object) - Method in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
 
equals(Object) - Method in class com.hazelcast.map.impl.LazyMapEntry
 
equals(Object) - Method in class com.hazelcast.map.impl.MapEntrySimple
 
equals(Object) - Method in class com.hazelcast.map.impl.MapPartitionLostEventFilter
 
equals(Object) - Method in class com.hazelcast.map.impl.MapRecordKey
 
equals(Object) - Method in class com.hazelcast.map.impl.operation.MapFlushWaitNotifyKey
 
equals(Object) - Method in class com.hazelcast.map.impl.query.QueryEventFilter
 
equals(Object) - Method in class com.hazelcast.map.impl.query.QueryResultRow
 
equals(Object) - Method in class com.hazelcast.map.impl.querycache.event.BatchEventData
 
equals(Object) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
equals(Object) - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
equals(Object) - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
 
equals(Object) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
equals(Object) - Method in class com.hazelcast.map.impl.wan.WanMapEntryView
 
equals(Object) - Method in class com.hazelcast.memory.MemorySize
 
equals(Object) - Method in class com.hazelcast.multimap.impl.MultiMapEventFilter
 
equals(Object) - Method in class com.hazelcast.multimap.impl.MultiMapRecord
 
equals(Object) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
equals(Object) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
equals(Object) - Method in class com.hazelcast.partition.PartitionAwareKey
 
equals(Object) - Method in class com.hazelcast.projection.impl.MultiAttributeProjection
 
equals(Object) - Method in class com.hazelcast.projection.impl.SingleAttributeProjection
 
equals(Object) - Method in class com.hazelcast.query.impl.CachedQueryEntry
 
equals(Object) - Method in class com.hazelcast.query.impl.CompositeValue
 
equals(Object) - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
 
equals(Object) - Method in class com.hazelcast.query.impl.predicates.AndPredicate
 
equals(Object) - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
 
equals(Object) - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
 
equals(Object) - Method in class com.hazelcast.query.impl.predicates.FalsePredicate
 
equals(Object) - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
 
equals(Object) - Method in class com.hazelcast.query.impl.predicates.InPredicate
 
equals(Object) - Method in class com.hazelcast.query.impl.predicates.InstanceOfPredicate
 
equals(Object) - Method in class com.hazelcast.query.impl.predicates.LikePredicate
 
equals(Object) - Method in class com.hazelcast.query.impl.predicates.NotEqualPredicate
 
equals(Object) - Method in class com.hazelcast.query.impl.predicates.NotPredicate
 
equals(Object) - Method in class com.hazelcast.query.impl.predicates.OrPredicate
 
equals(Object) - Method in class com.hazelcast.query.impl.predicates.PartitionPredicateImpl
 
equals(Object) - Method in class com.hazelcast.query.impl.predicates.RegexPredicate
 
equals(Object) - Method in class com.hazelcast.query.impl.predicates.SqlPredicate
 
equals(Object) - Method in class com.hazelcast.query.impl.predicates.TruePredicate
 
equals(Object) - Method in class com.hazelcast.query.impl.QueryEntry
 
equals(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
equals(Object) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
equals(Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
equals(Object) - Method in class com.hazelcast.ringbuffer.impl.RingbufferWaitNotifyKey
 
equals(Object) - Method in class com.hazelcast.scheduledexecutor.impl.DelegatingScheduledFutureStripper
 
equals(Object) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorWaitNotifyKey
 
equals(Object) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskDescriptor
 
equals(Object) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
 
equals(Object) - Method in class com.hazelcast.scheduledexecutor.impl.TaskDefinition
 
equals(Object) - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
equals(Object) - Method in class com.hazelcast.security.permission.AllPermissions
 
equals(Object) - Method in class com.hazelcast.security.permission.ClusterPermission
 
equals(Object) - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
equals(Object) - Method in class com.hazelcast.security.permission.InstancePermission
 
equals(Object) - Method in class com.hazelcast.security.SimpleTokenCredentials
 
equals(Object) - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
equals(Object) - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
equals(Object) - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
 
equals(Object) - Method in class com.hazelcast.spi.impl.eventservice.impl.TrueEventFilter
 
equals(Object) - Method in class com.hazelcast.spi.impl.merge.AbstractCollectionMergingValueImpl
 
equals(Object) - Method in class com.hazelcast.spi.impl.merge.AbstractMergingEntryImpl
 
equals(Object) - Method in class com.hazelcast.spi.impl.merge.AbstractMergingValueImpl
 
equals(Object) - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
equals(Object) - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
equals(Object) - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
equals(Object) - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
equals(Object) - Method in class com.hazelcast.spi.impl.merge.RingbufferMergingValueImpl
 
equals(Object) - Method in class com.hazelcast.spi.impl.operationservice.AbstractWaitNotifyKey
 
equals(Object) - Method in class com.hazelcast.spi.impl.servicemanager.ServiceInfo
 
equals(Object) - Method in class com.hazelcast.spi.impl.tenantcontrol.NoopTenantControl
 
equals(Object) - Method in class com.hazelcast.spi.partition.PartitionMigrationEvent
 
equals(Object) - Method in class com.hazelcast.splitbrainprotection.impl.ProbabilisticSplitBrainProtectionFunction
 
equals(Object) - Method in class com.hazelcast.splitbrainprotection.impl.RecentlyActiveSplitBrainProtectionFunction
 
equals(Object) - Method in class com.hazelcast.transaction.impl.TransactionalObjectKey
 
equals(Object) - Method in class com.hazelcast.transaction.impl.xa.SerializableXID
 
equals(Object) - Method in class com.hazelcast.version.MemberVersion
 
equals(Object) - Method in class com.hazelcast.version.Version
 
equalsIgnoreCase(String, String) - Static method in class com.hazelcast.internal.util.StringUtil
Returns true if two strings are equals ignoring the letter case in StringUtil.LOCALE_INTERNAL locale.
ERROR - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
 
ERROR_RESPONSE - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
ErrorCommand - Class in com.hazelcast.internal.ascii.memcache
 
ErrorCommand(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.internal.ascii.memcache.ErrorCommand
 
ErrorCommand(TextCommandConstants.TextCommandType, String) - Constructor for class com.hazelcast.internal.ascii.memcache.ErrorCommand
 
ErrorCommandProcessor - Class in com.hazelcast.internal.ascii.memcache
 
ErrorCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.memcache.ErrorCommandProcessor
 
errorHandler(ChannelErrorHandler) - Method in class com.hazelcast.internal.networking.nio.NioNetworking.Context
 
ErrorHolder - Class in com.hazelcast.client.impl.protocol.exception
 
ErrorHolder(int, String, String, List<StackTraceElement>) - Constructor for class com.hazelcast.client.impl.protocol.exception.ErrorHolder
 
ErrorHolderCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
ErrorResponse - Class in com.hazelcast.spi.impl.operationservice.impl.responses
 
ErrorResponse() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.ErrorResponse
 
ErrorResponse(Throwable, long, boolean) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.ErrorResponse
 
ErrorsCodec - Class in com.hazelcast.client.impl.protocol.codec.builtin
 
escapeMetricNamePart(String) - Static method in class com.hazelcast.internal.metrics.MetricsUtil
Escapes a user-supplied string value that is to be used as metrics key tag or value.
escapeSpecialCharacters(StringBuilder) - Static method in class com.hazelcast.client.impl.statistics.Statistics
 
escapeSpecialCharacters(StringBuilder, int) - Static method in class com.hazelcast.client.impl.statistics.Statistics
 
estimate() - Method in interface com.hazelcast.cardinality.CardinalityEstimator
Estimates the cardinality of the aggregation so far.
estimate() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
 
ESTIMATE - Static variable in class com.hazelcast.cardinality.impl.CardinalityEstimatorDataSerializerHook
 
estimate() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorProxy
 
estimate() - Method in interface com.hazelcast.cardinality.impl.hyperloglog.HyperLogLog
Computes a new estimate for the current status of the registers.
estimate() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.DenseHyperLogLogEncoder
 
estimate() - Method in interface com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogEncoder
Computes a new estimate for the current status of the registers.
estimate() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogImpl
 
estimate() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.SparseHyperLogLogEncoder
 
estimate() - Method in class com.hazelcast.client.impl.proxy.ClientCardinalityEstimatorProxy
 
estimateAsync() - Method in interface com.hazelcast.cardinality.CardinalityEstimator
Estimates the cardinality of the aggregation so far.
estimateAsync() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorProxy
 
estimateAsync() - Method in class com.hazelcast.client.impl.proxy.ClientCardinalityEstimatorProxy
 
estimatedSize() - Method in class com.hazelcast.query.impl.AndResultSet
 
estimatedSize() - Method in class com.hazelcast.query.impl.OrResultSet
 
estimatedSizeOf(Collection<QueryableEntry>) - Static method in class com.hazelcast.query.impl.predicates.PredicateUtils
In case of AndResultSet and OrResultSet calling size() may be very expensive so quicker estimatedSize() is used.
estimateMapCost(long, boolean, boolean) - Static method in class com.hazelcast.query.impl.IndexHeapMemoryCostUtil
Estimates the on-heap memory cost of a map backing an index.
EstimateOperation - Class in com.hazelcast.cardinality.impl.operations
 
EstimateOperation() - Constructor for class com.hazelcast.cardinality.impl.operations.EstimateOperation
 
EstimateOperation(String) - Constructor for class com.hazelcast.cardinality.impl.operations.EstimateOperation
 
estimateValueCost(Object) - Static method in class com.hazelcast.query.impl.IndexHeapMemoryCostUtil
Estimates the on-heap memory cost of the given value.
EUREKA_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
EurekaConfig - Class in com.hazelcast.config
Configuration for the Eureka Discovery Strategy.
EurekaConfig() - Constructor for class com.hazelcast.config.EurekaConfig
 
EurekaConfig(EurekaConfig) - Constructor for class com.hazelcast.config.EurekaConfig
 
eval(Object) - Method in class com.hazelcast.cache.impl.CacheEventListenerAdaptor
 
eval(Object) - Method in class com.hazelcast.cache.impl.event.CachePartitionLostEventFilter
 
eval(Object) - Method in class com.hazelcast.collection.impl.collection.CollectionEventFilter
 
eval(Object) - Method in class com.hazelcast.collection.impl.queue.QueueEventFilter
 
eval(Object) - Method in class com.hazelcast.map.impl.EntryEventFilter
 
eval(Object) - Method in class com.hazelcast.map.impl.EventListenerFilter
 
eval(Object) - Method in class com.hazelcast.map.impl.MapPartitionLostEventFilter
 
eval(Object) - Method in class com.hazelcast.map.impl.nearcache.invalidation.UuidFilter
 
eval(Object) - Method in class com.hazelcast.map.impl.query.QueryEventFilter
 
eval(Object) - Method in class com.hazelcast.multimap.impl.MultiMapEventFilter
 
eval(Object) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedEntryEventFilter
 
eval(Object) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedQueryEventFilter
 
eval(Object) - Method in interface com.hazelcast.spi.impl.eventservice.EventFilter
Returns true if the event matches this filter.
eval(Object) - Method in class com.hazelcast.spi.impl.eventservice.impl.TrueEventFilter
 
evaluate(Iterable<C>) - Method in class com.hazelcast.internal.eviction.impl.evaluator.EvictionPolicyEvaluator
Selects the best candidate to be evicted.
evaluateQueryEventFilter(EventFilter, Data, Object, String) - Method in class com.hazelcast.map.impl.event.AbstractFilteringStrategy
Evalues the filter using a CachedQueryEntry together with the value Extractors configured for this map.
Event - Interface in com.hazelcast.internal.management.events
Represents events sent to Management Center.
EVENT_ENVELOPE - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
EVENT_JOURNAL_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
EVENT_JOURNAL_DESERIALIZING_CACHE_EVENT - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
EVENT_JOURNAL_DESERIALIZING_MAP_EVENT - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
EVENT_JOURNAL_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
EVENT_JOURNAL_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
EVENT_JOURNAL_INITIAL_SUBSCRIBER_STATE - Static variable in class com.hazelcast.internal.journal.EventJournalDataSerializerHook
EVENT_JOURNAL_INTERNAL_CACHE_EVENT - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
EVENT_JOURNAL_INTERNAL_MAP_EVENT - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
EVENT_JOURNAL_READ - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
EVENT_JOURNAL_READ_OPERATION - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
EVENT_JOURNAL_READ_RESULT_SET - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
EVENT_JOURNAL_READ_RESULT_SET - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
EVENT_JOURNAL_SUBSCRIBE_OPERATION - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
EVENT_JOURNAL_SUBSCRIBE_OPERATION - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
EVENT_LISTENER_FILTER - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
EVENT_QUEUE_CAPACITY - Static variable in class com.hazelcast.client.properties.ClientProperty
Capacity of the executor that handles the incoming event packets.
EVENT_QUEUE_CAPACITY - Static variable in class com.hazelcast.spi.properties.GroupProperty
The capacity of the EventServiceImpl executor.
EVENT_QUEUE_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The timeout for offering an event to the event executor for processing.
EVENT_SYNC_FREQUENCY_PROP - Static variable in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
Usually remote events are sent asynchronously.
EVENT_SYNC_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
To prevent overloading of the outbound connections, once in a while an event is made synchronous by wrapping it in a fake operation and waiting for a fake response.
EVENT_THREAD_COUNT - Static variable in class com.hazelcast.client.properties.ClientProperty
Number of the threads to handle the incoming event packets.
EVENT_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Number of threads for the EventServiceImpl executor.
EVENT_TYPE - Static variable in class com.hazelcast.map.EventLostEvent
Event type ID.
EventBatch - Class in com.hazelcast.internal.management.events
Batch of events to be sent to Management Center.
EventBatch(String, String, List<Event>) - Constructor for class com.hazelcast.internal.management.events.EventBatch
 
eventBuilder(String) - Method in interface com.hazelcast.internal.auditlog.AuditlogService
Returns an instance of the EventBuilder interface.
EventBuilder<T extends EventBuilder<T>> - Interface in com.hazelcast.internal.auditlog
Builder interface for AuditableEvent instances.
eventBuilder(String) - Method in class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService
 
eventCount() - Method in class com.hazelcast.internal.networking.nio.NioThread
 
EventData - Interface in com.hazelcast.map.impl.event
General contract for map event data.
eventDataExcludingValues() - Method in interface com.hazelcast.map.impl.event.EntryEventDataCache
eventDataIncludingValues() - Method in interface com.hazelcast.map.impl.event.EntryEventDataCache
EventEnvelope - Class in com.hazelcast.spi.impl.eventservice.impl
An Envelope around an event object.
EventEnvelope() - Constructor for class com.hazelcast.spi.impl.eventservice.impl.EventEnvelope
 
eventFilter - Variable in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
 
EventFilter - Interface in com.hazelcast.spi.impl.eventservice
A predicate that can filter out events.
EventHandler<E> - Interface in com.hazelcast.client.impl.spi
Base interface for all client EventHandlers.
eventJournal - Variable in class com.hazelcast.cache.impl.AbstractCacheService
 
EventJournal<E> - Interface in com.hazelcast.internal.journal
The event journal is a container for events related to a data structure.
EventJournalCacheEvent<K,V> - Interface in com.hazelcast.cache.impl.journal
The event for the cache event journal.
eventJournalConfig - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
eventJournalConfig - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
Event Journal configuration
eventJournalConfig - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
Event Journal configuration
eventJournalConfig - Variable in class com.hazelcast.config.AbstractCacheConfig
 
EventJournalConfig - Class in com.hazelcast.config
Configuration for an event journal.
EventJournalConfig() - Constructor for class com.hazelcast.config.EventJournalConfig
 
EventJournalConfig(EventJournalConfig) - Constructor for class com.hazelcast.config.EventJournalConfig
eventJournalConfig - Variable in class com.hazelcast.map.impl.MapContainer
 
EventJournalConfigCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
EventJournalConfigReadOnly - Class in com.hazelcast.internal.config
 
EventJournalConfigReadOnly(EventJournalConfig) - Constructor for class com.hazelcast.internal.config.EventJournalConfigReadOnly
 
EventJournalDataSerializerHook - Class in com.hazelcast.internal.journal
Data serializer hook for common classes related to the EventJournal.
EventJournalDataSerializerHook() - Constructor for class com.hazelcast.internal.journal.EventJournalDataSerializerHook
 
EventJournalInitialSubscriberState - Class in com.hazelcast.internal.journal
The response for the event journal subcription.
EventJournalInitialSubscriberState() - Constructor for class com.hazelcast.internal.journal.EventJournalInitialSubscriberState
 
EventJournalInitialSubscriberState(long, long) - Constructor for class com.hazelcast.internal.journal.EventJournalInitialSubscriberState
 
EventJournalMapEvent<K,V> - Interface in com.hazelcast.map.journal
The event for the map event journal.
EventJournalReader<E> - Interface in com.hazelcast.internal.journal
This interface provides methods to subscribe and read from an event journal.
EventJournalReadOperation<T,J> - Class in com.hazelcast.internal.journal
Reads from the map event journal in batches.
EventJournalReadOperation() - Constructor for class com.hazelcast.internal.journal.EventJournalReadOperation
 
EventJournalReadOperation(String, long, int, int) - Constructor for class com.hazelcast.internal.journal.EventJournalReadOperation
 
EventJournalWriterRecordStoreMutationObserver - Class in com.hazelcast.map.impl.recordstore
 
EventJournalWriterRecordStoreMutationObserver(MapEventJournal, MapContainer, int) - Constructor for class com.hazelcast.map.impl.recordstore.EventJournalWriterRecordStoreMutationObserver
 
EventListenerFilter - Class in com.hazelcast.map.impl
Event filter matching events of specified types.
EventListenerFilter() - Constructor for class com.hazelcast.map.impl.EventListenerFilter
 
EventListenerFilter(int, EventFilter) - Constructor for class com.hazelcast.map.impl.EventListenerFilter
 
eventLost(EventLostEvent) - Method in interface com.hazelcast.map.listener.EventLostListener
Invoked upon lost of event or events.
EventLostEvent - Class in com.hazelcast.map
This event is fired in case of an event lost detection.
EventLostEvent(String, Member, int) - Constructor for class com.hazelcast.map.EventLostEvent
 
EventLostListener - Interface in com.hazelcast.map.listener
Invoked upon lost of event or events.
EventMetadata - Class in com.hazelcast.internal.management.events
 
EventMetadata(EventMetadata.EventType, long) - Constructor for class com.hazelcast.internal.management.events.EventMetadata
 
EventMetadata.EventType - Enum in com.hazelcast.internal.management.events
 
EventProcessor - Class in com.hazelcast.spi.impl.eventservice.impl
An event processor responsible of fetching the registration and service responsible for the published event and processing it.
EventProcessor(EventServiceImpl, EventEnvelope, int) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.EventProcessor
 
EventPublisherAccumulatorProcessor - Class in com.hazelcast.map.impl.querycache.publisher
Publish events which will be received by subscriber sides.
EventPublisherAccumulatorProcessor(QueryCacheEventService) - Constructor for class com.hazelcast.map.impl.querycache.publisher.EventPublisherAccumulatorProcessor
 
EventPublisherAccumulatorProcessor(AccumulatorInfo, QueryCacheEventService) - Constructor for class com.hazelcast.map.impl.querycache.publisher.EventPublisherAccumulatorProcessor
 
EventPublisherHelper - Class in com.hazelcast.map.impl.querycache.subscriber
Helper class for publishing events to QueryCache listeners.
eventPublishingService - Variable in class com.hazelcast.map.impl.MapService
 
EventPublishingService<E,T> - Interface in com.hazelcast.spi.impl.eventservice
A service for publishing events.
eventQueueCapacity - Variable in class com.hazelcast.internal.management.dto.EventServiceDTO
 
EventQueuePlugin - Class in com.hazelcast.internal.diagnostics
The EventQueuePlugin checks the event queue and samples the event types if the size is above a certain threshold.
EventQueuePlugin(NodeEngineImpl, StripedExecutor) - Constructor for class com.hazelcast.internal.diagnostics.EventQueuePlugin
 
EventQueuePlugin(ILogger, StripedExecutor, HazelcastProperties) - Constructor for class com.hazelcast.internal.diagnostics.EventQueuePlugin
 
eventQueueSize - Variable in class com.hazelcast.internal.management.dto.EventServiceDTO
 
EventRegistration - Interface in com.hazelcast.spi.impl.eventservice
The result of a Event Registration.
eventsBatchingEnabled - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
eventsEnabled - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
eventService - Variable in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
 
eventService - Variable in class com.hazelcast.map.impl.event.MapEventPublisherImpl
 
eventService - Variable in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
eventService - Variable in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
EventService - Interface in com.hazelcast.spi.impl.eventservice
Component responsible for handling events like topic events or map.listener events.
EventServiceDTO - Class in com.hazelcast.internal.management.dto
A Serializable DTO for EventServiceMBean.
EventServiceDTO() - Constructor for class com.hazelcast.internal.management.dto.EventServiceDTO
 
EventServiceDTO(EventService) - Constructor for class com.hazelcast.internal.management.dto.EventServiceDTO
 
EventServiceImpl - Class in com.hazelcast.spi.impl.eventservice.impl
Service responsible for routing and dispatching local and remote events and keeping track of listener registrations.
EventServiceImpl(NodeEngineImpl) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
EventServiceMBean - Class in com.hazelcast.internal.jmx
Management bean for EventService
EventServiceMBean(HazelcastInstance, EventService, ManagementService) - Constructor for class com.hazelcast.internal.jmx.EventServiceMBean
 
EventServiceSegment<S> - Class in com.hazelcast.spi.impl.eventservice.impl
Segment of the event service.
EventServiceSegment(String, S) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.EventServiceSegment
 
eventThreadCount - Variable in class com.hazelcast.internal.management.dto.EventServiceDTO
 
eventType - Variable in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
 
eventType - Variable in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
 
eventType - Variable in class com.hazelcast.map.impl.operation.BasePutOperation
 
evict(K) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
evict(K) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
evict(K) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
evict(K) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
evict(K) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
evict(K) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
evict(S, EvictionPolicyEvaluator<A, E>, EvictionChecker, EvictionListener<A, E>) - Method in class com.hazelcast.internal.eviction.impl.strategy.sampling.SamplingEvictionStrategy
Does eviction if required.
evict(K) - Method in interface com.hazelcast.map.IMap
Evicts the specified key from this map.
evict(RecordStore, Data) - Method in interface com.hazelcast.map.impl.eviction.Evictor
Evict supplied record-store.
evict(RecordStore, Data) - Method in class com.hazelcast.map.impl.eviction.EvictorImpl
 
EVICT - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
evict(Data) - Method in class com.hazelcast.map.impl.operation.MapOperation
 
evict(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
evict(Data, boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
evict(Data, boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
evict(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
evict(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
evict(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
EVICT_ALL - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
EVICT_ALL_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
EVICT_ALL_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
EVICT_ALWAYS - Static variable in interface com.hazelcast.internal.eviction.EvictionChecker
 
EVICT_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
EVICT_BATCH_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
Evictable<V> - Interface in com.hazelcast.internal.eviction
Interface for entries, records or whatever that can be evicted.
EvictableEntryView<K,V> - Interface in com.hazelcast.internal.eviction
Contract point (from the end user perspective) for serving/accessing entries that can be evicted.
EvictableStore<A,E extends Evictable> - Interface in com.hazelcast.internal.eviction
Interface for store implementations that holds Evictable entries to evict.
evictAll() - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
evictAll() - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
evictAll() - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
evictAll() - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
evictAll() - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
evictAll() - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
evictAll() - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
evictAll() - Method in interface com.hazelcast.map.IMap
Evicts all keys from this map except the locked ones.
evictAll() - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
evictAll(boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
evictAll(boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Evicts all keys except locked ones.
EvictAllBackupOperation - Class in com.hazelcast.map.impl.operation
Operation which evicts all keys except locked ones.
EvictAllBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.EvictAllBackupOperation
 
EvictAllBackupOperation(String) - Constructor for class com.hazelcast.map.impl.operation.EvictAllBackupOperation
 
evictAllInternal() - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
EvictAllOperation - Class in com.hazelcast.map.impl.operation
Operation which evicts all keys except locked ones.
EvictAllOperation() - Constructor for class com.hazelcast.map.impl.operation.EvictAllOperation
 
EvictAllOperation(String) - Constructor for class com.hazelcast.map.impl.operation.EvictAllOperation
 
EvictAllOperationFactory - Class in com.hazelcast.map.impl.operation
Operation factory for evict all operations.
EvictAllOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.EvictAllOperationFactory
 
EvictAllOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.EvictAllOperationFactory
 
EvictBackupOperation - Class in com.hazelcast.map.impl.operation
 
EvictBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.EvictBackupOperation
 
EvictBackupOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.EvictBackupOperation
 
EvictBatchBackupOperation - Class in com.hazelcast.map.impl.operation
Used to transfer expired keys from owner replica to backup replicas.
EvictBatchBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.EvictBatchBackupOperation
 
EvictBatchBackupOperation(String, Collection<ExpiredKey>, int) - Constructor for class com.hazelcast.map.impl.operation.EvictBatchBackupOperation
 
evictEntries(Data) - Method in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
evictEntries(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Evicts entries from this record-store.
evictExpiredEntries(int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
evictExpiredEntries(int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Do expiration operations.
evictExpiredEntries(int, boolean) - Method in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
evictExpiredEntries(int, boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Do expiration operations.
evictIfExpired(Data, R, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
evictIfExpired(Record, long, boolean) - Method in class com.hazelcast.map.impl.recordstore.RecordStoreAdapter
 
evictIfExpired(R, long, boolean) - Method in interface com.hazelcast.map.impl.StoreAdapter
Checks whether the record is expired and evicts it if so.
evictIfRequired() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
evictIfRequired() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Evict cache record store if eviction is required.
evictIfSame(ExpiredKey) - Method in class com.hazelcast.cache.impl.operation.CacheExpireBatchBackupOperation
 
evictInternal(Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
evictInternal(Object) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
evictInternal(S, EvictionPolicyEvaluator<A, E>, EvictionListener<A, E>) - Method in class com.hazelcast.internal.eviction.impl.strategy.sampling.SamplingEvictionStrategy
Processes sampling based eviction logic on SampleableEvictableStore.
evictInternal(Object) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
EVICTION - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
EvictionCandidate<A,E extends Evictable> - Interface in com.hazelcast.internal.eviction
Interface for entries, records or whatever that can be evictable via its accessor (key or ID).
evictionChecker - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
EvictionChecker - Interface in com.hazelcast.internal.eviction
Checks whether a specific max size threshold is exceeded or not according to configured MaxSizeConfig.MaxSizePolicy and indicates whether eviction is required.
evictionChecker - Variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
EvictionChecker - Class in com.hazelcast.map.impl.eviction
Checks whether a specific threshold is exceeded or not according to configured MaxSizeConfig.MaxSizePolicy to start eviction process.
EvictionChecker(MemoryInfoAccessor, MapServiceContext) - Constructor for class com.hazelcast.map.impl.eviction.EvictionChecker
 
evictionChecker - Variable in class com.hazelcast.map.impl.eviction.EvictorImpl
 
evictionCheckers - Variable in class com.hazelcast.internal.eviction.CompositeEvictionChecker
 
evictionConfig - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
evictionConfig - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
cache eviction configuration
EvictionConfig - Class in com.hazelcast.config
Configuration for eviction.
EvictionConfig() - Constructor for class com.hazelcast.config.EvictionConfig
 
EvictionConfig(EvictionConfig) - Constructor for class com.hazelcast.config.EvictionConfig
 
EvictionConfig.MaxSizePolicy - Enum in com.hazelcast.config
Maximum Size Policy
EvictionConfigHolder - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
Client protocol adapter for (@link EvictionConfig
EvictionConfigHolder(int, String, String, String, Data) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.EvictionConfigHolder
 
EvictionConfigHolderCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
EvictionConfigReadOnly - Class in com.hazelcast.internal.config
Read only version of EvictionConfig.
EvictionConfigReadOnly(EvictionConfig) - Constructor for class com.hazelcast.internal.config.EvictionConfigReadOnly
 
EvictionConfiguration - Interface in com.hazelcast.internal.eviction
Interface for configuration information about eviction.
evictionDisabled - Variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
EvictionListener<A,E extends Evictable> - Interface in com.hazelcast.internal.eviction
Interface for entries, records or whatever that can be evicted via its accessor (key or ID).
EvictionOperation - Class in com.hazelcast.replicatedmap.impl.operation
Evicts set of entries from the record store.
EvictionOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.EvictionOperation
 
EvictionOperation(ReplicatedRecordStore, Collection<ScheduledEntry<Object, Object>>) - Constructor for class com.hazelcast.replicatedmap.impl.operation.EvictionOperation
 
evictionPolicy - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
eviction policy.
evictionPolicy - Variable in class com.hazelcast.config.EvictionConfig
 
EvictionPolicy - Enum in com.hazelcast.config
Eviction Policy enum.
EvictionPolicyComparator<K,V,E extends EvictableEntryView<K,V>> - Class in com.hazelcast.internal.eviction
A kind of Comparator to be used while comparing entries to be evicted.
EvictionPolicyComparator() - Constructor for class com.hazelcast.internal.eviction.EvictionPolicyComparator
 
evictionPolicyEvaluator - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
EvictionPolicyEvaluator<A,E extends Evictable> - Class in com.hazelcast.internal.eviction.impl.evaluator
Default EvictionPolicyEvaluator implementation.
EvictionPolicyEvaluator(EvictionPolicyComparator) - Constructor for class com.hazelcast.internal.eviction.impl.evaluator.EvictionPolicyEvaluator
 
evictionPolicyEvaluator - Variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
EvictionPolicyEvaluatorProvider - Class in com.hazelcast.internal.eviction
Provider to get any kind (EvictionPolicy) of EvictionPolicyEvaluator.
EVICTIONS - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
evictions - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
evictionStrategy - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
evictionStrategy - Variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
EvictionStrategyType - Enum in com.hazelcast.internal.eviction
Enum for Eviction Strategy types
EvictOperation - Class in com.hazelcast.map.impl.operation
 
EvictOperation(String, Data, boolean) - Constructor for class com.hazelcast.map.impl.operation.EvictOperation
 
EvictOperation() - Constructor for class com.hazelcast.map.impl.operation.EvictOperation
 
Evictor - Interface in com.hazelcast.map.impl.eviction
Evicts a RecordStore.
evictor - Variable in class com.hazelcast.map.impl.MapContainer
 
EvictorImpl - Class in com.hazelcast.map.impl.eviction
Evictor helper methods.
EvictorImpl(MapEvictionPolicy, EvictionChecker, IPartitionService, int) - Constructor for class com.hazelcast.map.impl.eviction.EvictorImpl
 
evictRecords(Collection<Record>) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
EXCEPTION_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.builtin.ErrorsCodec
 
ExceptionAction - Enum in com.hazelcast.spi.impl.operationservice
The possible actions that can be taken when a certain exception is thrown.
exceptionally(Function<Throwable, ? extends V>) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
exceptionally(Function<Throwable, ? extends ClientMessage>) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
exceptionally(Function<Throwable, ? extends V>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
exceptionally(Function<Throwable, ? extends V>) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
exceptionally(Function<Throwable, ? extends V>) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
ExceptionalResult(Throwable) - Constructor for class com.hazelcast.spi.impl.AbstractInvocationFuture.ExceptionalResult
 
exceptionResponse(Throwable) - Static method in class com.hazelcast.internal.ascii.rest.HttpPostCommandProcessor
 
ExceptionUtil - Class in com.hazelcast.internal.util
Contains various exception related utility methods.
ExceptionUtil.RuntimeExceptionFactory - Interface in com.hazelcast.internal.util
Interface used by rethrow/peel to wrap the peeled exception
execute(Runnable) - Method in class com.hazelcast.client.impl.protocol.task.AbstractAddressMessageTask
 
execute(Runnable) - Method in class com.hazelcast.client.impl.protocol.task.AbstractPartitionMessageTask
 
execute(Runnable) - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
execute(Runnable) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
execute(Runnable, MemberSelector) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
execute(Runnable) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheScheduler
 
execute(Runnable) - Method in class com.hazelcast.client.impl.spi.impl.ClientExecutionServiceImpl
 
execute(Runnable, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
Executes a task on a randomly selected member.
execute(Runnable) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Executes the given task on the underlying task execution mechanism.
execute(Runnable) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
execute(Callable) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorContainer
 
execute(Runnable) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
execute(String, UUID, T, Operation) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
 
execute(Runnable, MemberSelector) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
execute(Runnable) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
execute(Runnable) - Method in class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
execute(Runnable) - Method in class com.hazelcast.internal.util.executor.StripedExecutor
 
execute(Aggregator, Collection<QueryableEntry>, PartitionIdSet) - Method in interface com.hazelcast.map.impl.query.AccumulationExecutor
 
execute(Aggregator, Collection<QueryableEntry>, PartitionIdSet) - Method in class com.hazelcast.map.impl.query.CallerRunsAccumulationExecutor
 
execute(String, Predicate, Collection<Integer>, Result) - Method in class com.hazelcast.map.impl.query.CallerRunsPartitionScanExecutor
 
execute(String, Predicate, int, int, int) - Method in class com.hazelcast.map.impl.query.CallerRunsPartitionScanExecutor
 
execute(Aggregator, Collection<QueryableEntry>, PartitionIdSet) - Method in class com.hazelcast.map.impl.query.ParallelAccumulationExecutor
 
execute(String, Predicate, Collection<Integer>, Result) - Method in class com.hazelcast.map.impl.query.ParallelPartitionScanExecutor
 
execute(String, Predicate, int, int, int) - Method in class com.hazelcast.map.impl.query.ParallelPartitionScanExecutor
Executes the predicate on a partition chunk.
execute(String, Predicate, Collection<Integer>, Result) - Method in interface com.hazelcast.map.impl.query.PartitionScanExecutor
 
execute(String, Predicate, int, int, int) - Method in interface com.hazelcast.map.impl.query.PartitionScanExecutor
Executes the predicate on a partition chunk.
execute(Query, Target) - Method in interface com.hazelcast.map.impl.query.QueryEngine
Executes the given query on the given target.
execute(Query, Target) - Method in class com.hazelcast.map.impl.query.QueryEngineImpl
 
execute(Runnable) - Method in interface com.hazelcast.map.impl.querycache.QueryCacheScheduler
Executes a task.
execute(Runnable) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheScheduler
 
execute(Executor, Object) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture.AbstractBiNode
 
execute(Executor, Object) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture.AbstractEitherNode
 
execute(Executor, Object) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture.ApplyNode
 
execute(Executor, Object) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture.ComposeNode
 
execute(Object) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture.ExceptionallyNode
 
execute(Executor, Object) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture.RunNode
 
execute(String, Runnable) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
execute(Runnable) - Method in class com.hazelcast.spi.impl.executionservice.impl.DelegatingTaskScheduler
 
execute(String, Runnable) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
execute(Operation) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
execute(PartitionSpecificRunnable) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
execute(Operation) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
Executes the given Operation at some point in the future.
execute(PartitionSpecificRunnable) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
Executes the given PartitionSpecificRunnable at some point in the future.
execute(PartitionSpecificRunnable) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
execute(Operation) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
execute(Operation) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Executes an operation in the operation executor pool.
execute(PartitionSpecificRunnable) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Executes a PartitionSpecificRunnable.
execute(TransactionalTaskContext) - Method in interface com.hazelcast.transaction.TransactionalTask
Executes the transactional logic.
executeAll() - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorPartitionContainer
 
executeAsync(Runnable) - Method in interface com.hazelcast.internal.nio.IOService
 
executeAsync(Runnable) - Method in class com.hazelcast.internal.nio.NodeIOService
 
executedLocally() - Method in class com.hazelcast.spi.impl.operationservice.Operation
Returns true if local member is the caller.
executedOperationCount - Variable in class com.hazelcast.internal.management.dto.OperationServiceDTO
 
executedOperationsCount() - Method in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
 
executeDurable(String, Runnable) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
executeDurable(String, Runnable) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
executeEventCallback(Runnable) - Method in interface com.hazelcast.spi.impl.eventservice.EventService
Executes an event callback on a random event thread.
executeEventCallback(Runnable) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
Executes an event callback on a random event thread.
executeLocallyWithRetry(NodeEngine, Operation) - Static method in class com.hazelcast.internal.util.InvocationUtil
Constructs a local execution with retry logic.
executeOnAllMembers(Runnable) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
executeOnAllMembers(Runnable) - Method in interface com.hazelcast.core.IExecutorService
Executes a task on all of the known cluster members.
executeOnAllMembers(Runnable) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
executeOnEntries(EntryProcessor<K, V, R>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
executeOnEntries(EntryProcessor<K, V, R>, Predicate<K, V>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
executeOnEntries(EntryProcessor) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
executeOnEntries(EntryProcessor, Predicate) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
executeOnEntries(EntryProcessor) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
executeOnEntries(EntryProcessor, Predicate) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
executeOnEntries(EntryProcessor) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
executeOnEntries(EntryProcessor, Predicate) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
executeOnEntries(EntryProcessor) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
executeOnEntries(EntryProcessor, Predicate) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
executeOnEntries(EntryProcessor) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
executeOnEntries(EntryProcessor, Predicate) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
executeOnEntries(EntryProcessor<K, V, R>) - Method in interface com.hazelcast.map.IMap
Applies the user defined EntryProcessor to the all entries in the map.
executeOnEntries(EntryProcessor<K, V, R>, Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
Applies the user defined EntryProcessor to the entries in the map which satisfy provided predicate.
executeOnEntries(EntryProcessor<K, V, R>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
executeOnEntries(EntryProcessor<K, V, R>, Predicate<K, V>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
executeOnEntriesInternal(EntryProcessor, Predicate, List<Data>) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
executeOnKey(K, EntryProcessor<K, V, R>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
executeOnKey(K, EntryProcessor) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
executeOnKey(K, EntryProcessor) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
executeOnKey(K, EntryProcessor) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
executeOnKey(K, EntryProcessor) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
executeOnKey(K, EntryProcessor) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
executeOnKey(K, EntryProcessor<K, V, R>) - Method in interface com.hazelcast.map.IMap
Applies the user defined EntryProcessor to the entry mapped by the key.
executeOnKey(K, EntryProcessor<K, V, R>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
executeOnKeyInternal(Object, EntryProcessor<K, V, R>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
executeOnKeyInternal(Object, EntryProcessor<K, V, R>) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
executeOnKeyInternal(Object, EntryProcessor) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
executeOnKeyInternal(Object, EntryProcessor<K, V, R>, ExecutionCallback<? super R>) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
executeOnKeyOwner(Runnable, Object) - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
executeOnKeyOwner(Runnable, Object) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
executeOnKeyOwner(Runnable, Object) - Method in interface com.hazelcast.core.IExecutorService
Executes a task on the owner of the specified key.
executeOnKeyOwner(Runnable, Object) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Executes a task on the owner of the specified key.
executeOnKeyOwner(Runnable, Object) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
executeOnKeyOwner(Runnable, Object) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
executeOnKeys(Set<K>, EntryProcessor<K, V, R>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
executeOnKeys(Set<K>, EntryProcessor) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
executeOnKeys(Set<K>, EntryProcessor) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
executeOnKeys(Set<K>, EntryProcessor) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
executeOnKeys(Set<K>, EntryProcessor) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
executeOnKeys(Set<K>, EntryProcessor) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
executeOnKeys(Set<K>, EntryProcessor<K, V, R>) - Method in interface com.hazelcast.map.IMap
Applies the user defined EntryProcessor to the entries mapped by the collection of keys.
executeOnKeys(Set<K>, EntryProcessor<K, V, R>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
executeOnMember(Runnable, Member) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
executeOnMember(Runnable, Member) - Method in interface com.hazelcast.core.IExecutorService
Executes a task on the specified member.
executeOnMember(Runnable, Member) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
executeOnMembers(Runnable, Collection<Member>) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
executeOnMembers(Runnable, MemberSelector) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
executeOnMembers(Runnable, Collection<Member>) - Method in interface com.hazelcast.core.IExecutorService
Executes a task on each of the specified members.
executeOnMembers(Runnable, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
Executes a task on each of the selected members.
executeOnMembers(Runnable, MemberSelector) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
executeOnMembers(Runnable, Collection<Member>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
executeOnPartitions(PartitionTaskFactory, BitSet) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
executeOnPartitions(PartitionTaskFactory, BitSet) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
Executes a task from the taskFactory for each of the given partitions.
executeOnPartitions(PartitionTaskFactory, BitSet) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
executeOnPartitions(PartitionTaskFactory, BitSet) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Executes for each of the partitions, a task created by the taskFactory.
executeOnPartitionThreads(Runnable) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
executeOnPartitionThreads(Runnable) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
Executes the task on every partition thread.
executeOperation(Operation) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientInvokerWrapper
 
executeOperation(Operation) - Method in interface com.hazelcast.map.impl.querycache.InvokerWrapper
 
executeOperation(Operation) - Method in class com.hazelcast.map.impl.querycache.NodeInvokerWrapper
 
executeRun() - Method in class com.hazelcast.internal.util.executor.HazelcastManagedThread
Does the actual run and can be overridden to customize.
ExecuteScriptRequest - Class in com.hazelcast.internal.management.request
Request for executing scripts on the nodes from Management Center.
ExecuteScriptRequest() - Constructor for class com.hazelcast.internal.management.request.ExecuteScriptRequest
 
ExecuteScriptRequest(String, String, Set<String>) - Constructor for class com.hazelcast.internal.management.request.ExecuteScriptRequest
 
executeTransaction(TransactionalTask<T>) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
executeTransaction(TransactionalTask<T>) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
executeTransaction(TransactionalTask<T>) - Method in interface com.hazelcast.client.impl.spi.ClientTransactionManagerService
 
executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in interface com.hazelcast.client.impl.spi.ClientTransactionManagerService
 
executeTransaction(TransactionalTask<T>) - Method in class com.hazelcast.client.impl.spi.impl.ClientTransactionManagerServiceImpl
 
executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in class com.hazelcast.client.impl.spi.impl.ClientTransactionManagerServiceImpl
 
executeTransaction(TransactionalTask<T>) - Method in interface com.hazelcast.core.HazelcastInstance
Executes the given transactional task in current thread using default options and returns the result of the task.
executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in interface com.hazelcast.core.HazelcastInstance
Executes the given transactional task in current thread using given options and returns the result of the task.
executeTransaction(TransactionalTask<T>) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
executeTransaction(TransactionalTask<T>) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in interface com.hazelcast.transaction.TransactionManagerService
 
executeWithDelay() - Method in class com.hazelcast.internal.util.scheduler.CoalescingDelayedTrigger
invoke delayed execution.
EXECUTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
ExecutionCallback<V> - Interface in com.hazelcast.core
ExecutionCallback allows to asynchronously get notified when the execution is completed, either successfully or with error.
executionCallback - Variable in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
 
ExecutionCallbackAdapter<T> - Class in com.hazelcast.executor.impl
ExecutionCallbackAdapter(ExecutionCallback<T>) - Constructor for class com.hazelcast.executor.impl.ExecutionCallbackAdapter
 
ExecutionExceptionDecorator(Throwable) - Constructor for exception com.hazelcast.scheduledexecutor.impl.ScheduledTaskResult.ExecutionExceptionDecorator
 
ExecutionService - Interface in com.hazelcast.spi.impl.executionservice
A Service responsible for providing access to 'system' executors and customer executors.
executionService - Variable in class com.hazelcast.spi.impl.operationservice.Offload
 
ExecutionServiceImpl - Class in com.hazelcast.spi.impl.executionservice.impl
 
ExecutionServiceImpl(NodeEngineImpl) - Constructor for class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
executor - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReliableTopicConfigCodec.RequestParameters
a serialized Executor instance to use for executing message listeners or null
EXECUTOR_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
EXECUTOR_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
EXECUTOR_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
EXECUTOR_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
EXECUTOR_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ExecutorConfig - Class in com.hazelcast.config
Contains the configuration for an IExecutorService.
ExecutorConfig() - Constructor for class com.hazelcast.config.ExecutorConfig
 
ExecutorConfig(String) - Constructor for class com.hazelcast.config.ExecutorConfig
 
ExecutorConfig(String, int) - Constructor for class com.hazelcast.config.ExecutorConfig
 
ExecutorConfig(ExecutorConfig) - Constructor for class com.hazelcast.config.ExecutorConfig
 
ExecutorConfigReadOnly - Class in com.hazelcast.internal.config
Configuration for Executor(Read Only)
ExecutorConfigReadOnly(ExecutorConfig) - Constructor for class com.hazelcast.internal.config.ExecutorConfigReadOnly
 
ExecutorDataSerializerHook - Class in com.hazelcast.executor.impl
 
ExecutorDataSerializerHook() - Constructor for class com.hazelcast.executor.impl.ExecutorDataSerializerHook
 
ExecutorServiceCancelOnAddressCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ExecutorServiceCancelOnAddressCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ExecutorServiceCancelOnAddressCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ExecutorServiceCancelOnAddressMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice
 
ExecutorServiceCancelOnAddressMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnAddressMessageTask
 
ExecutorServiceCancelOnPartitionCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ExecutorServiceCancelOnPartitionCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ExecutorServiceCancelOnPartitionCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ExecutorServiceCancelOnPartitionMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice
 
ExecutorServiceCancelOnPartitionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnPartitionMessageTask
 
ExecutorServiceIsShutdownCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns true if this executor has been shut down.
ExecutorServiceIsShutdownCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ExecutorServiceIsShutdownCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ExecutorServiceIsShutdownMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice
 
ExecutorServiceIsShutdownMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
 
ExecutorServiceMBean - Class in com.hazelcast.internal.jmx
Management bean for IExecutorService
ExecutorServiceMBean(IExecutorService, ManagementService) - Constructor for class com.hazelcast.internal.jmx.ExecutorServiceMBean
 
ExecutorServicePermission - Class in com.hazelcast.security.permission
 
ExecutorServicePermission(String, String...) - Constructor for class com.hazelcast.security.permission.ExecutorServicePermission
 
ExecutorServiceProxy - Class in com.hazelcast.executor.impl
 
ExecutorServiceProxy(String, NodeEngine, DistributedExecutorService) - Constructor for class com.hazelcast.executor.impl.ExecutorServiceProxy
 
ExecutorServiceShutdownCodec - Class in com.hazelcast.client.impl.protocol.codec
Initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
ExecutorServiceShutdownCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ExecutorServiceShutdownCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ExecutorServiceShutdownMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice
 
ExecutorServiceShutdownMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
 
ExecutorServiceSubmitToAddressCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ExecutorServiceSubmitToAddressCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ExecutorServiceSubmitToAddressCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ExecutorServiceSubmitToAddressMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice
 
ExecutorServiceSubmitToAddressMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
 
ExecutorServiceSubmitToPartitionCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ExecutorServiceSubmitToPartitionCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ExecutorServiceSubmitToPartitionCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ExecutorServiceSubmitToPartitionMessageTask - Class in com.hazelcast.client.impl.protocol.task.executorservice
 
ExecutorServiceSubmitToPartitionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
 
ExecutorType - Enum in com.hazelcast.internal.util.executor
 
existInMemory(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
existInMemory(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Checks if the key exist in memory without trying to load data from map-loader
exists() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
EXPAND_THRESHOLD_OFFSET - Static variable in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
expansionThreshold() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray
Array expansion and rehashing will be triggered when size reaches this value.
expansionThreshold() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
expected - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongCompareAndSetCodec.RequestParameters
The expected value
expectedNextIndex() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendFailureResponse
 
expectedRound - Variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchCountDownCodec.RequestParameters
The round this invocation will be performed on
Expirable - Interface in com.hazelcast.internal.eviction
Expiring Data model interface.
EXPIRATION_TIME - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
ExpirationChecker<E extends Expirable> - Interface in com.hazelcast.internal.eviction
Interface for entries, records or whatever that can be checked for expiration.
expirationIterator - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
expirationIterator - Variable in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
Iterates over a pre-set entry count/percentage in one round.
expirationManager - Variable in class com.hazelcast.cache.impl.AbstractCacheService
 
ExpirationManager - Class in com.hazelcast.internal.eviction
This class is responsible for gradual cleanup of expired entries from IMap and ICache.
ExpirationManager(ClearExpiredRecordsTask, NodeEngine) - Constructor for class com.hazelcast.internal.eviction.ExpirationManager
 
expirationTaskFuture - Variable in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
expirationTime - Variable in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
expirationTime() - Method in class com.hazelcast.cp.internal.session.CPSessionInfo
 
expirationTime() - Method in interface com.hazelcast.cp.session.CPSession
Returns the timestamp of when the session will expire
expirationTime - Variable in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
expirationTime - Variable in class com.hazelcast.map.impl.record.RecordInfo
 
ExpirationTimeMergePolicy<V,T extends MergingExpirationTime<V>> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination data structure if the source entry will expire later than the destination entry.
ExpirationTimeMergePolicy() - Constructor for class com.hazelcast.spi.merge.ExpirationTimeMergePolicy
 
ExpirationTimeSetter - Class in com.hazelcast.map.impl
Utility methods for setting TTL and max idle seconds.
EXPIRE_BATCH_BACKUP - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
EXPIRE_SESSIONS_OP - Static variable in class com.hazelcast.cp.internal.session.RaftSessionServiceDataSerializerHook
 
EXPIRE_WAIT_KEYS_OP - Static variable in class com.hazelcast.cp.internal.datastructures.RaftDataServiceDataSerializerHook
 
ExpiredKey - Class in com.hazelcast.internal.eviction
Holds expired key and related metadata.
ExpiredKey(Data, long) - Constructor for class com.hazelcast.internal.eviction.ExpiredKey
 
expiredKeys - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
expiredKeys - Variable in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
expiredWaitKeyResponse() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchService
 
expiredWaitKeyResponse() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockService
 
expiredWaitKeyResponse() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreService
 
expiredWaitKeyResponse() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
Creates the response object that will be sent for a expired wait key.
expireSessions(CPGroupId, Collection<BiTuple<Long, Long>>) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
ExpireSessionsOp - Class in com.hazelcast.cp.internal.session.operation
Expires sessions that do have not committed any heartbeat for CPSubsystemConfig.getSessionTimeToLiveSeconds() seconds.
ExpireSessionsOp() - Constructor for class com.hazelcast.cp.internal.session.operation.ExpireSessionsOp
 
ExpireSessionsOp(Collection<BiTuple<Long, Long>>) - Constructor for class com.hazelcast.cp.internal.session.operation.ExpireSessionsOp
 
expireWaitKeys(CPGroupId, Collection<BiTuple<String, UUID>>) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
ExpireWaitKeysOp - Class in com.hazelcast.cp.internal.datastructures.spi.blocking.operation
Expires the given wait keys on the given blocking service.
ExpireWaitKeysOp() - Constructor for class com.hazelcast.cp.internal.datastructures.spi.blocking.operation.ExpireWaitKeysOp
 
ExpireWaitKeysOp(String, Collection<BiTuple<String, UUID>>) - Constructor for class com.hazelcast.cp.internal.datastructures.spi.blocking.operation.ExpireWaitKeysOp
 
EXPIRIES - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
expiries - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
EXPIRY_POLICY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
expiryDelayMillis - Variable in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
expiryPolicy - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
expiryPolicy - Variable in class com.hazelcast.cache.impl.record.CacheObjectRecord
 
expiryPolicy - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAllCodec.RequestParameters
Expiry policy for the entry.
expiryPolicy - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAndReplaceCodec.RequestParameters
Expiry policy for the entry.
expiryPolicy - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetCodec.RequestParameters
Expiry policy for the entry.
expiryPolicy - Variable in class com.hazelcast.client.impl.protocol.codec.CachePutAllCodec.RequestParameters
expiry policy for the entry.
expiryPolicy - Variable in class com.hazelcast.client.impl.protocol.codec.CachePutCodec.RequestParameters
Expiry policy for the entry.
expiryPolicy - Variable in class com.hazelcast.client.impl.protocol.codec.CachePutIfAbsentCodec.RequestParameters
The custom expiry policy for this operation.
expiryPolicy - Variable in class com.hazelcast.client.impl.protocol.codec.CacheReplaceCodec.RequestParameters
Expiry policy for the entry.
expiryPolicy - Variable in class com.hazelcast.client.impl.protocol.codec.CacheSetExpiryPolicyCodec.RequestParameters
custom expiry policy for this operation
expiryPolicyFactory - Variable in class com.hazelcast.config.AbstractCacheConfig
The Factory for the ExpiryPolicy.
expiryPolicyFactoryClassName - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
expiry policy factory class name.
ExpiryPolicyFactoryConfig() - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
ExpiryPolicyFactoryConfig(String) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
ExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
EXPLICIT_SUSPICION - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
ExplicitSuspicionOp - Class in com.hazelcast.internal.cluster.impl.operations
An operation which is sent by a member that wants to be explicitly suspected by the target.
ExplicitSuspicionOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.ExplicitSuspicionOp
 
ExplicitSuspicionOp(MembersViewMetadata) - Constructor for class com.hazelcast.internal.cluster.impl.operations.ExplicitSuspicionOp
 
expression - Variable in class com.hazelcast.query.impl.predicates.LikePredicate
 
EXTENDED_BIND_MESSAGE - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
ExtendedBindMessage - Class in com.hazelcast.internal.cluster.impl
Extended bind message, conveying information about all kinds of public addresses per protocol type.
ExtendedBindMessage() - Constructor for class com.hazelcast.internal.cluster.impl.ExtendedBindMessage
 
ExtendedBindMessage(byte, Map<ProtocolType, Collection<Address>>, Address, boolean) - Constructor for class com.hazelcast.internal.cluster.impl.ExtendedBindMessage
 
extendLeaseTime(Data, UUID, long, long) - Method in interface com.hazelcast.internal.locksupport.LockStore
Extend the lease time for an already locked key.
extendLeaseTime(Data, UUID, long, long) - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
extendLeaseTime(Data, UUID, long, long) - Method in class com.hazelcast.internal.locksupport.LockStoreProxy
 
extendLock(Data, UUID, long, long) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
extendLock(Data, UUID, long, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
extendLock(Data, UUID, long, long) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
EXTENSION_PRIORITY_LIST - Static variable in class com.hazelcast.instance.impl.DefaultNodeContext
 
ExternalizableSerializer(boolean, ClassNameFilter) - Constructor for class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.ExternalizableSerializer
 
extract(T, A, ValueCollector) - Method in interface com.hazelcast.query.extractor.ValueExtractor
Extracts a value from the given target object.
extract(Object, String, Object) - Method in class com.hazelcast.query.impl.getters.Extractors
 
Extractable - Interface in com.hazelcast.query.impl
Enables extracting attribute value from an object, usually from an Entry
extractAndAppendResult(Collection<AccumulatedResults>, QueryResult) - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
 
extractAndAppendResult(Collection<AggregationResult>, AggregationResult) - Method in class com.hazelcast.client.impl.protocol.task.map.DefaultMapAggregateMessageTask
 
extractAndAppendResult(Collection<QueryResult>, QueryResult) - Method in class com.hazelcast.client.impl.protocol.task.map.DefaultMapProjectMessageTask
 
extractAndAppendResult(Collection<QueryResultRow>, QueryResult) - Method in class com.hazelcast.client.impl.protocol.task.map.DefaultMapQueryMessageTask
 
extractArgumentsFromAttributeName(String) - Static method in class com.hazelcast.query.impl.getters.ExtractorHelper
 
extractAttributeNameNameWithoutArguments(String) - Static method in class com.hazelcast.query.impl.getters.ExtractorHelper
 
extractAttributeType(Object) - Static method in class com.hazelcast.query.impl.QueryableEntry
Deduces the AttributeType of the given non-null attribute value.
extractExpiryPolicyOfRecord(CacheRecord) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
extractFrom(Object) - Method in class com.hazelcast.query.impl.getters.AbstractMultiValueGetter
 
extractFrom(Object) - Method in class com.hazelcast.query.impl.getters.FieldGetter
 
extractFrom(Object) - Method in class com.hazelcast.query.impl.getters.MethodGetter
 
extractInt(long, boolean) - Static method in class com.hazelcast.internal.nio.Bits
 
extractMemberMetadata(Member, InternalCompletableFuture, InvalidationMetaDataFetcher.MetadataHolder) - Method in class com.hazelcast.client.cache.impl.nearcache.invalidation.ClientCacheInvalidationMetaDataFetcher
 
extractMemberMetadata(Member, InternalCompletableFuture, InvalidationMetaDataFetcher.MetadataHolder) - Method in class com.hazelcast.client.map.impl.nearcache.invalidation.ClientMapInvalidationMetaDataFetcher
 
extractMemberMetadata(Member, InternalCompletableFuture, InvalidationMetaDataFetcher.MetadataHolder) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationMetaDataFetcher
 
extractMemberMetadata(Member, InternalCompletableFuture, InvalidationMetaDataFetcher.MetadataHolder) - Method in class com.hazelcast.map.impl.nearcache.invalidation.MemberMapInvalidationMetaDataFetcher
 
extractMetrics(MetricTagger, Object) - Method in interface com.hazelcast.internal.metrics.MetricsExtractor
Extracts the metrics from the given source and tags them with the provided tagger.
ExtractorHelper - Class in com.hazelcast.query.impl.getters
 
extractors - Variable in class com.hazelcast.map.impl.MapContainer
 
extractors - Variable in class com.hazelcast.query.impl.AbstractIndex
 
Extractors - Class in com.hazelcast.query.impl.getters
 
extractors(Extractors) - Method in class com.hazelcast.query.impl.Indexes.Builder
 
extractors - Variable in class com.hazelcast.query.impl.QueryableEntry
 
Extractors.Builder - Class in com.hazelcast.query.impl.getters
Builder which is used to create a new Extractors object.
extractPartitionAware(OperationFactory) - Static method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionAwareFactoryAccessor
 
extractRecordFromLazy(EntryView) - Method in interface com.hazelcast.map.impl.recordstore.Storage
 
extractRecordFromLazy(EntryView) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
extractShort(int, boolean) - Static method in class com.hazelcast.internal.nio.Bits
 
extractValue(Object, String) - Static method in class com.hazelcast.query.impl.getters.ReflectionHelper
 

F

F_ID - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.cardinality.impl.CardinalityEstimatorDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.client.impl.ClientDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.cp.internal.datastructures.lock.LockDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.cp.internal.datastructures.RaftDataServiceDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.cp.internal.raft.impl.RaftDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.cp.internal.session.RaftSessionServiceDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.durableexecutor.impl.DurableExecutorDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.internal.ascii.TextProtocolsDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.internal.crdt.CRDTDataSerializerHook
The CRDT (de)serializer factory ID
F_ID - Static variable in class com.hazelcast.internal.journal.EventJournalDataSerializerHook
Factory ID for the event journal IdentifiedDataSerializable classes
F_ID - Static variable in class com.hazelcast.internal.locksupport.LockDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.internal.longregister.LongRegisterDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.internal.management.ManagementDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.internal.partition.impl.PartitionPortableHook
 
F_ID - Static variable in class com.hazelcast.internal.usercodedeployment.impl.UserCodeDeploymentSerializerHook
 
F_ID - Static variable in class com.hazelcast.map.impl.client.MapPortableHook
 
F_ID - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.projection.impl.ProjectionDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
 
F_ID - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
 
F_ID - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.topic.impl.TopicDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.wan.impl.WanDataSerializerHook
 
F_ID_OFFSET_HIBERNATE - Static variable in interface com.hazelcast.internal.serialization.DataSerializerHook
 
F_ID_OFFSET_WEBMODULE - Static variable in interface com.hazelcast.internal.serialization.DataSerializerHook
 
FACTOR - Static variable in class com.hazelcast.internal.util.scheduler.SecondsBasedEntryTaskScheduler
 
FACTORY_ID - Static variable in class com.hazelcast.internal.metrics.managementcenter.MetricsDataSerializerHook
 
FactoryIdHelper - Class in com.hazelcast.internal.serialization.impl
 
FAIL_ON_INDETERMINATE_OPERATION_STATE - Static variable in class com.hazelcast.client.properties.ClientProperty
When this configuration is enabled, if an operation has sync backups and acks are not received from backup replicas in time, or the member which owns primary replica of the target partition leaves the cluster, then the invocation fails with IndeterminateOperationStateException.
FAIL_ON_INDETERMINATE_OPERATION_STATE - Static variable in class com.hazelcast.spi.properties.GroupProperty
When this configuration is enabled, if an operation has sync backups and acks are not received from backup replicas in time, or the member which owns primary replica of the target partition leaves the cluster, then the invocation fails with IndeterminateOperationStateException.
FAILED_RESULT - Static variable in class com.hazelcast.internal.management.request.ForceStartNodeRequest
Result sent within response when force start triggering failed
FAILED_RESULT - Static variable in class com.hazelcast.internal.management.request.TriggerPartialStartRequest
Result sent within response when partial start triggering failed
FailFastCallIdSequence - Class in com.hazelcast.spi.impl.sequence
A CallIdSequence that provides backpressure by taking the number of in-flight operations into account when before creating a new call-id.
FailFastCallIdSequence(int, ConcurrencyDetection) - Constructor for class com.hazelcast.spi.impl.sequence.FailFastCallIdSequence
 
failOnIndeterminateOperationState - Variable in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
 
FailoverClientConfigSupport - Class in com.hazelcast.client.impl.clientside
Static methods to resolve and validate multiple client configs for blue green feature
FailureDetector - Interface in com.hazelcast.internal.cluster.fd
Failure detector tracks heartbeats of a member and decides liveness/availability of the member.
FALSE - Static variable in class com.hazelcast.internal.json.Json
Represents the JSON literal false.
FALSE - Static variable in class com.hazelcast.internal.json.JsonValue
Deprecated.
Use Json.FALSE instead
FALSE_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
FalsePredicate<K,V> - Class in com.hazelcast.query.impl.predicates
A Predicate which always returns false.
FalsePredicate() - Constructor for class com.hazelcast.query.impl.predicates.FalsePredicate
 
fastForwardToEndFrame(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.CodecUtil
 
fastIntMix(int) - Static method in class com.hazelcast.internal.util.HashUtil
Hash function based on Knuth's multiplicative method.
fastLongMix(long) - Static method in class com.hazelcast.internal.util.HashUtil
Hash function based on Knuth's multiplicative method.
FastMultiResultSet - Class in com.hazelcast.query.impl
Multiple result set for Predicates.
FastMultiResultSet() - Constructor for class com.hazelcast.query.impl.FastMultiResultSet
 
fence - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockGetLockOwnershipCodec.ResponseParameters
TODO DOC
fence() - Method in class com.hazelcast.cp.internal.datastructures.lock.AcquireResult
 
FencedLock - Interface in com.hazelcast.cp.lock
A linearizable & distributed & reentrant implementation of Lock.
FencedLockConfig - Class in com.hazelcast.config.cp
Contains configuration options for FencedLock
FencedLockConfig() - Constructor for class com.hazelcast.config.cp.FencedLockConfig
 
FencedLockConfig(String) - Constructor for class com.hazelcast.config.cp.FencedLockConfig
 
FencedLockConfig(String, int) - Constructor for class com.hazelcast.config.cp.FencedLockConfig
 
FencedLockGetLockOwnershipCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns current lock ownership status of the given FencedLock instance.
FencedLockGetLockOwnershipCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
FencedLockGetLockOwnershipCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
FencedLockLockCodec - Class in com.hazelcast.client.impl.protocol.codec
Acquires the given FencedLock on the given CP group.
FencedLockLockCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
FencedLockLockCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
FencedLockProxy - Class in com.hazelcast.client.cp.internal.datastructures.lock
Client-side proxy of Raft-based FencedLock API
FencedLockProxy(ClientContext, RaftGroupId, String, String) - Constructor for class com.hazelcast.client.cp.internal.datastructures.lock.FencedLockProxy
 
FencedLockProxy - Class in com.hazelcast.cp.internal.datastructures.lock.proxy
Server-side proxy of Raft-based FencedLock API
FencedLockProxy(NodeEngine, RaftGroupId, String, String) - Constructor for class com.hazelcast.cp.internal.datastructures.lock.proxy.FencedLockProxy
 
FencedLockTryLockCodec - Class in com.hazelcast.client.impl.protocol.codec
Attempts to acquire the given FencedLock on the given CP group.
FencedLockTryLockCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
FencedLockTryLockCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
FencedLockUnlockCodec - Class in com.hazelcast.client.impl.protocol.codec
Unlocks the given FencedLock on the given CP group.
FencedLockUnlockCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
FencedLockUnlockCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
fetch() - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
fetch() - Method in class com.hazelcast.cache.impl.ClusterWideIterator
 
fetch() - Method in class com.hazelcast.client.cache.impl.ClientClusterWideIterator
 
fetch() - Method in class com.hazelcast.client.map.impl.ClientMapPartitionIterator
 
fetch() - Method in class com.hazelcast.client.map.impl.ClientMapQueryPartitionIterator
 
fetch() - Method in class com.hazelcast.map.impl.iterator.AbstractMapPartitionIterator
 
fetch() - Method in class com.hazelcast.map.impl.iterator.AbstractMapQueryPartitionIterator
 
fetch() - Method in class com.hazelcast.map.impl.iterator.MapPartitionIterator
 
fetch() - Method in class com.hazelcast.map.impl.iterator.MapQueryPartitionIterator
 
FETCH_ENTRIES - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
FETCH_KEYS - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
FETCH_MEMBER_LIST_STATE - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
FETCH_PARTITION_STATE - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
FETCH_WITH_QUERY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
fetchEntries(int, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
fetchEntries(int, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Starting from the provided table index, a set of entries are returned with a maximum size of size
fetchEntries(int, int) - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap
 
fetchEntries(int, int) - Method in interface com.hazelcast.cache.impl.record.CacheRecordMap
Fetches entries in bulk as specified size at most.
fetchEntries(int, int, List<Map.Entry<K, V>>) - Method in class com.hazelcast.internal.util.SampleableConcurrentHashMap
Fetches entries from given tableIndex as size and puts them into entries list.
fetchEntries(int, int) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
fetchEntries(int, int) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Fetches specified number of entries from provided tableIndex.
fetchEntries(int, int, SerializationService) - Method in interface com.hazelcast.map.impl.recordstore.Storage
Fetch minimally size items from the tableIndex position.
fetchEntries(int, int, SerializationService) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
fetchKeys(int, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
fetchKeys(int, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Starting from the provided table index, a set of keys are returned with a maximum size of size
fetchKeys(int, int) - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap
 
fetchKeys(int, int) - Method in interface com.hazelcast.cache.impl.record.CacheRecordMap
Fetches keys in bulk as specified size at most.
fetchKeys(int, int, List<K>) - Method in class com.hazelcast.internal.util.SampleableConcurrentHashMap
Fetches keys from given tableIndex as size and puts them into keys list.
fetchKeys(int, int) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
fetchKeys(int, int) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Fetches specified number of keys from provided tableIndex.
fetchKeys(int, int) - Method in interface com.hazelcast.map.impl.recordstore.Storage
Fetch minimally size keys from the tableIndex position.
fetchKeys(int, int) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
FetchMembersViewOp - Class in com.hazelcast.internal.cluster.impl.operations
An operation sent by the member that starts mastership claim process to fetch/gather member views of other members.
FetchMembersViewOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.FetchMembersViewOp
 
FetchMembersViewOp(UUID) - Constructor for class com.hazelcast.internal.cluster.impl.operations.FetchMembersViewOp
 
fetchMetadata(ConcurrentMap<String, RepairingHandler>) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationMetaDataFetcher
 
fetchMetadataOf(Address, List<String>) - Method in class com.hazelcast.client.cache.impl.nearcache.invalidation.ClientCacheInvalidationMetaDataFetcher
 
fetchMetadataOf(Address, List<String>) - Method in class com.hazelcast.client.map.impl.nearcache.invalidation.ClientMapInvalidationMetaDataFetcher
 
fetchMetadataOf(Address, List<String>) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationMetaDataFetcher
 
fetchMetadataOf(Address, List<String>) - Method in class com.hazelcast.map.impl.nearcache.invalidation.MemberMapInvalidationMetaDataFetcher
 
FetchPartitionStateOperation - Class in com.hazelcast.internal.partition.operation
Operation sent by the master to the cluster members to fetch their partition state.
FetchPartitionStateOperation() - Constructor for class com.hazelcast.internal.partition.operation.FetchPartitionStateOperation
 
fetchSize - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
fetchSize - Variable in class com.hazelcast.map.impl.iterator.AbstractMapPartitionIterator
 
fetchSize - Variable in class com.hazelcast.map.impl.iterator.AbstractMapQueryPartitionIterator
 
FieldDefinition - Interface in com.hazelcast.nio.serialization
FieldDefinition defines name, type, index of a field
FieldDefinitionImpl - Class in com.hazelcast.internal.serialization.impl
 
FieldDefinitionImpl(int, String, FieldType, int) - Constructor for class com.hazelcast.internal.serialization.impl.FieldDefinitionImpl
 
FieldDefinitionImpl(int, String, FieldType, int, int, int) - Constructor for class com.hazelcast.internal.serialization.impl.FieldDefinitionImpl
 
FieldGetter - Class in com.hazelcast.query.impl.getters
 
FieldGetter(Getter, Field, String, Class) - Constructor for class com.hazelcast.query.impl.getters.FieldGetter
 
FieldGetter(Getter, Field, String, Class, Class) - Constructor for class com.hazelcast.query.impl.getters.FieldGetter
 
fieldsToString() - Method in class com.hazelcast.config.CollectionConfig
Returns field names with values as concatenated String so it can be used in child classes' toString() methods.
FieldType - Enum in com.hazelcast.nio.serialization
 
FILE_NAME - Static variable in class com.hazelcast.internal.util.DirectoryLock
 
FileMetricSet - Class in com.hazelcast.internal.metrics.metricsets
A MetricSet for files.
filename() - Method in class com.hazelcast.cp.internal.raft.impl.persistence.LogFileStructure
 
FILENAME_PREFIX - Static variable in class com.hazelcast.internal.diagnostics.Diagnostics
Configures the prefix for the diagnostics file.
FileSystemXmlConfig - Class in com.hazelcast.config
A Config which includes functionality for loading itself from a XML configuration file.
FileSystemXmlConfig(String) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
Creates a Config based on a Hazelcast xml file and uses the System.properties to resolve variables in the XML.
FileSystemXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
Creates a Config based on a Hazelcast XML file.
FileSystemXmlConfig(File) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
Creates a Config based on a Hazelcast xml file and uses the System.properties to resolve variables in the XML.
FileSystemXmlConfig(File, Properties) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
Creates a Config based on a Hazelcast XML file.
FileSystemYamlConfig - Class in com.hazelcast.config
A Config which includes functionality for loading itself from a YAML configuration file.
FileSystemYamlConfig(String) - Constructor for class com.hazelcast.config.FileSystemYamlConfig
Creates a Config based on a Hazelcast yaml file and uses the System.properties to resolve variables in the YAML.
FileSystemYamlConfig(String, Properties) - Constructor for class com.hazelcast.config.FileSystemYamlConfig
Creates a Config based on a Hazelcast YAML file.
FileSystemYamlConfig(File) - Constructor for class com.hazelcast.config.FileSystemYamlConfig
Creates a Config based on a Hazelcast yaml file and uses the System.properties to resolve variables in the YAML.
FileSystemYamlConfig(File, Properties) - Constructor for class com.hazelcast.config.FileSystemYamlConfig
Creates a Config based on a Hazelcast YAML file.
fillAttributesForAliasedDiscoveryStrategy(AliasedDiscoveryConfig, Node, BeanDefinitionBuilder, String) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
fillAttributeValues(Node, BeanDefinitionBuilder, String...) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
fillAttributeValues(Node, BeanDefinitionBuilder, Collection<String>) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
fillDataSerializableFactories(Node, SerializationConfig) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
fillJavaSerializationFilter(Node, SerializationConfig) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
fillNativeMemoryConfig(Node, NativeMemoryConfig) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
fillPartitionToKeyData(Set<K>, Map<Integer, List<Data>>, Map<Object, Data>, Map<Data, Object>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
fillPortableFactories(Node, SerializationConfig) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
fillProperties(Node, Map<String, Comparable>) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
fillProperties(Node, Properties) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
fillProperties(Node, Map<String, Comparable>, boolean) - Static method in class com.hazelcast.config.DomConfigHelper
 
fillProperties(Node, Properties, boolean) - Static method in class com.hazelcast.config.DomConfigHelper
 
fillSerializers(Node, SerializationConfig) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
fillValues(Node, BeanDefinitionBuilder, String...) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
filter - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferReadManyCodec.RequestParameters
Filter is allowed to be null, indicating there is no filter.
filter(String) - Method in class com.hazelcast.internal.serialization.SerializationClassNameFilter
Throws SecurityException if the given class name appears on the blacklist or does not appear a whitelist.
Filter<T> - Interface in com.hazelcast.internal.util.filter
Decide whether an object matches a condition or not.
filter(IPredicate<E>, Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
Filters this queue according to supplied predicate.
filter(String) - Method in interface com.hazelcast.nio.serialization.ClassNameFilter
filter(QueryContext) - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
filter(QueryContext) - Method in class com.hazelcast.query.impl.predicates.AndPredicate
 
filter(QueryContext) - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
 
filter(QueryContext) - Method in class com.hazelcast.query.impl.predicates.BoundedRangePredicate
 
filter(QueryContext) - Method in class com.hazelcast.query.impl.predicates.CompositeEqualPredicate
 
filter(QueryContext) - Method in class com.hazelcast.query.impl.predicates.CompositeRangePredicate
 
filter(QueryContext) - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
 
filter(QueryContext) - Method in class com.hazelcast.query.impl.predicates.FalsePredicate
 
filter(QueryContext) - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
 
filter(QueryContext) - Method in interface com.hazelcast.query.impl.predicates.IndexAwarePredicate
Produces a filtered entry set by utilizing the indexes available while executing the query in the given query context.
filter(QueryContext) - Method in class com.hazelcast.query.impl.predicates.InPredicate
 
filter(QueryContext) - Method in class com.hazelcast.query.impl.predicates.OrPredicate
 
filter(QueryContext) - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
Used if inner predicate is instanceof IndexAwarePredicate for filtering.
filter(QueryContext) - Method in class com.hazelcast.query.impl.predicates.SqlPredicate
 
FILTER_DOES_NOT_MATCH - Static variable in interface com.hazelcast.map.impl.event.FilteringStrategy
Used as return value from FilteringStrategy.doFilter(EventFilter, Data, Object, Object, EntryEventType, String) to indicate that an event registration's filter does not match.
filterConnection(String, TcpIpConnection) - Method in class com.hazelcast.internal.nio.ascii.AllowingTextProtocolFilter
 
filterConnection(String, TcpIpConnection) - Method in class com.hazelcast.internal.nio.ascii.RestApiFilter
 
FilteringStrategy - Interface in com.hazelcast.map.impl.event
A filtering strategy determines whether an event must be published based on a specific filter and if so, may alter the type of event that should be published.
filteringStrategy - Variable in class com.hazelcast.map.impl.event.MapEventPublisherImpl
 
FINALIZE_JOIN - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
FINALIZE_REMOTE_TX - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
FINALIZE_REMOTE_TX_BACKUP - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
finalizeJoin(MembersView, Address, UUID, UUID, UUID, ClusterState, Version, long, long, OnJoinOp) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
FinalizeJoinOp - Class in com.hazelcast.internal.cluster.impl.operations
Sent by the master to all members to finalize the join operation from a joining/returning node.
FinalizeJoinOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.FinalizeJoinOp
 
FinalizeJoinOp(UUID, MembersView, OnJoinOp, OnJoinOp, long, UUID, long, ClusterState, Version, PartitionRuntimeState) - Constructor for class com.hazelcast.internal.cluster.impl.operations.FinalizeJoinOp
 
FinalizeMigrationOperation - Class in com.hazelcast.internal.partition.operation
Invoked locally on the source or destination of the migration to finalize the migration.
FinalizeMigrationOperation() - Constructor for class com.hazelcast.internal.partition.operation.FinalizeMigrationOperation
This constructor should not be used to obtain an instance of this class; it exists to fulfill IdentifiedDataSerializable coding conventions.
FinalizeMigrationOperation(MigrationInfo, MigrationEndpoint, boolean) - Constructor for class com.hazelcast.internal.partition.operation.FinalizeMigrationOperation
 
finalizePutAll(Map<? extends K, ? extends V>, Map<Integer, List<Map.Entry<Data, Data>>>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
finalizePutAll(Map<? extends K, ? extends V>, Map<Integer, List<Map.Entry<Data, Data>>>) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
finalizePutAll(Map<?, ?>) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
FinalizeRemoteTransactionBackupOperation - Class in com.hazelcast.transaction.impl.xa.operations
 
FinalizeRemoteTransactionBackupOperation() - Constructor for class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionBackupOperation
 
FinalizeRemoteTransactionBackupOperation(Data) - Constructor for class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionBackupOperation
 
FinalizeRemoteTransactionOperation - Class in com.hazelcast.transaction.impl.xa.operations
 
FinalizeRemoteTransactionOperation() - Constructor for class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
 
FinalizeRemoteTransactionOperation(Data, boolean) - Constructor for class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
 
finalizeReplicaSync(int, int, ServiceNamespace, long[]) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
Set the new replica versions for the partition with the partitionId and reset any ongoing replica synchronization request for this partition and replica index.
findCacheConfig(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
findCacheConfig(String, String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
findCacheConfig(String, String) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
 
findCacheConfig(String) - Method in interface com.hazelcast.cache.impl.ICacheService
 
findCacheConfig(String, String) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
 
findCacheConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
findCacheConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only CacheSimpleConfig configuration for the given name.
findCacheConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
findCacheConfigOrNull(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
findCacheConfigOrNull(String) - Method in class com.hazelcast.config.Config
Returns the cache config with the given name or null if there is none.
findCacheConfigOrNull(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
findCacheSimpleConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
findCacheSimpleConfig(String) - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Finds existing Cache config.
findCardinalityEstimatorConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
findCardinalityEstimatorConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only CardinalityEstimator configuration for the given name.
findCardinalityEstimatorConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
findCardinalityEstimatorConfig(String) - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Finds existing Cardinality Estimator config.
findCardinalityEstimatorConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
findDeadlockedThreads() - Static method in class com.hazelcast.internal.management.ThreadDumpGenerator
 
findDurableExecutorConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
findDurableExecutorConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only durable executor configuration for the given name.
findDurableExecutorConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
findDurableExecutorConfig(String) - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Finds existing Durable Executor config.
findDurableExecutorConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
findExecutorConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
findExecutorConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only executor configuration for the given name.
findExecutorConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
findExecutorConfig(String) - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Finds existing Executor config.
findExecutorConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
findFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.client.config.ClientConfig
Returns a ClientFlakeIdGeneratorConfig configuration for the given flake ID generator name.
findFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
findFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.config.Config
Returns a FlakeIdGeneratorConfig configuration for the given flake ID generator name.
findFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
findFlakeIdGeneratorConfig(String) - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Finds existing FlakeIdGeneratorConfig config.
findFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
findListConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
findListConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only IList configuration for the given name.
findListConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
findListConfig(String) - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Finds existing List config.
findListConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
findLoadedClass(String) - Method in class com.hazelcast.internal.usercodedeployment.impl.ClassLocator
 
findLoadedClass(String) - Method in class com.hazelcast.internal.usercodedeployment.UserCodeDeploymentService
 
findLockConfig(String) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the FencedLock configuration for the given name.
findMapConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
findMapConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only IMap configuration for the given name.
findMapConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
findMapConfig(String) - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Finds existing Map config.
findMapConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
findMultiMapConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
findMultiMapConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only MultiMap configuration for the given name.
findMultiMapConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
findMultiMapConfig(String) - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Finds existing Multimap config.
findMultiMapConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
findNextAddressToSendCreateRequest() - Method in class com.hazelcast.client.impl.spi.ProxyManager
 
findPNCounterConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
findPNCounterConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only PNCounterConfig configuration for the given name.
findPNCounterConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
findPNCounterConfig(String) - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Finds existing PN counter config.
findPNCounterConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
findQueueConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
findQueueConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only IQueue configuration for the given name.
findQueueConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
findQueueConfig(String) - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Finds existing Queue config.
findQueueConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
findReliableTopicConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
findReliableTopicConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only reliable topic configuration for the given name.
findReliableTopicConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
findReliableTopicConfig(String) - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Finds existing Reliable Topic config.
findReliableTopicConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
findReplicatedMapConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
findReplicatedMapConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only ReplicatedMap configuration for the given name.
findReplicatedMapConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
findReplicatedMapConfig(String) - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Finds existing ReplicatedMap config.
findReplicatedMapConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
findRingbufferConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
findRingbufferConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only Ringbuffer configuration for the given name.
findRingbufferConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
findRingbufferConfig(String) - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Finds existing Ringbuffer config.
findRingbufferConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
findScheduledExecutorConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
findScheduledExecutorConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only scheduled executor configuration for the given name.
findScheduledExecutorConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
findScheduledExecutorConfig(String) - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Finds existing Scheduled Executor config.
findScheduledExecutorConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
findSemaphoreConfig(String) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the CP ISemaphore configuration for the given name.
findSetConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
findSetConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only ISet configuration for the given name.
findSetConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
findSetConfig(String) - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Finds existing Set config.
findSetConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
findSplitBrainProtectionConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
findSplitBrainProtectionConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only split-brain protection configuration for the given name.
findSplitBrainProtectionConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
findTopicConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
findTopicConfig(String) - Method in class com.hazelcast.config.Config
Returns a read-only ITopic configuration for the given name.
findTopicConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
findTopicConfig(String) - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Finds existing Topic config.
findTopicConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
findValueWithPattern(NavigableJsonInputAdapter, JsonSchemaNode, JsonPattern, JsonPathCursor) - Static method in class com.hazelcast.json.internal.JsonSchemaHelper
Extract the JsonValue that is stored in attributePath in input.
fine(String) - Method in class com.hazelcast.logging.AbstractLogger
 
fine(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
fine(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
fine(String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at the Level.FINE level.
fine(Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a throwable at the Level.FINE level.
fine(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the Level.FINE level.
finest(String) - Method in class com.hazelcast.logging.AbstractLogger
 
finest(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
finest(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
finest(String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at the Level.FINEST level.
finest(Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a throwable at the Level.FINEST level.
finest(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the Level.FINEST level.
finishExecution(long) - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
 
fireEntryListenerEvent(Data, Data, Data, String, Address) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapEventPublishingService
 
fireEntryListenerEvent(Data, Data, Data, EntryEventType, String, Address) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapEventPublishingService
 
fireLifecycleEvent(LifecycleEvent.LifecycleState) - Method in class com.hazelcast.client.impl.clientside.LifecycleServiceImpl
 
fireLifecycleEvent(LifecycleEvent.LifecycleState) - Method in class com.hazelcast.instance.impl.LifecycleServiceImpl
 
fireLifecycleEvent(LifecycleEvent) - Method in class com.hazelcast.instance.impl.LifecycleServiceImpl
 
fireMapClearedEvent(int, String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapEventPublishingService
 
FIRST_ENTRY_HAS_HIGHER_PRIORITY_TO_BE_EVICTED - Static variable in class com.hazelcast.internal.eviction.EvictionPolicyComparator
Integer constant for representing behaviour for giving higher priority to first entry to be evicted.
firstArrangement() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
firstArrangement() - Method in interface com.hazelcast.internal.partition.InternalPartitionService
Causes the partition table to be arranged and published to members if : this instance has started this instance is the master the cluster is ClusterState.ACTIVE if the partition table has not already been arranged if there is no cluster membership change If this instance is not the master, it will trigger the master to assign the partitions.
firstChildElement(Node) - Static method in class com.hazelcast.config.DomConfigHelper
 
firstInvocationTimeMillis - Variable in class com.hazelcast.spi.impl.operationservice.impl.Invocation
The first time this invocation got executed.
FIXED_SUM - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
fixedPointSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
fixedPointSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
FixedSizeTypesCodec - Class in com.hazelcast.client.impl.protocol.codec.builtin
 
FixedSumAggregator<I> - Class in com.hazelcast.aggregation.impl
 
FixedSumAggregator() - Constructor for class com.hazelcast.aggregation.impl.FixedSumAggregator
 
FixedSumAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.FixedSumAggregator
 
fixScopeIdAndGetInetAddress(InetAddress) - Static method in class com.hazelcast.internal.util.AddressUtil
 
FLAG_JET_FLOW_CONTROL - Static variable in class com.hazelcast.internal.nio.Packet
Marks a Jet packet as Flow control
FLAG_OP_CONTROL - Static variable in class com.hazelcast.internal.nio.Packet
Marks an Operation packet as Operation control (like invocation-heartbeats)
FLAG_OP_RESPONSE - Static variable in class com.hazelcast.internal.nio.Packet
Marks an Operation packet as Response
FLAG_URGENT - Static variable in class com.hazelcast.internal.nio.Packet
Marks the packet as Urgent
FLAG_ZERO - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
 
flags - Variable in class com.hazelcast.client.impl.protocol.ClientMessage.Frame
 
FLAKE_ID_GENERATOR_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
FLAKE_ID_GENERATOR_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
FLAKE_ID_GENERATOR_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
FLAKE_ID_NODE_ID_OUT_OF_RANGE_EXCEPTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
FlakeIdGenerator - Interface in com.hazelcast.flakeidgen
A cluster-wide unique ID generator.
FlakeIdGeneratorConfig - Class in com.hazelcast.config
The FlakeIdGeneratorConfig contains the configuration for the member regarding Flake ID Generator.
FlakeIdGeneratorConfig(String) - Constructor for class com.hazelcast.config.FlakeIdGeneratorConfig
 
FlakeIdGeneratorConfig(FlakeIdGeneratorConfig) - Constructor for class com.hazelcast.config.FlakeIdGeneratorConfig
Copy-constructor
FlakeIdGeneratorConfigReadOnly - Class in com.hazelcast.internal.config
FlakeIdGeneratorConfigReadOnly(FlakeIdGeneratorConfig) - Constructor for class com.hazelcast.internal.config.FlakeIdGeneratorConfigReadOnly
 
FlakeIdGeneratorDataSerializerHook - Class in com.hazelcast.flakeidgen.impl
 
FlakeIdGeneratorDataSerializerHook() - Constructor for class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorDataSerializerHook
 
FlakeIdGeneratorNewIdBatchCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
FlakeIdGeneratorNewIdBatchCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
FlakeIdGeneratorNewIdBatchCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
FlakeIdGeneratorPermission - Class in com.hazelcast.security.permission
 
FlakeIdGeneratorPermission(String, String...) - Constructor for class com.hazelcast.security.permission.FlakeIdGeneratorPermission
 
FlakeIdGeneratorProxy - Class in com.hazelcast.flakeidgen.impl
 
FlakeIdGeneratorProxy.IdBatchAndWaitTime - Class in com.hazelcast.flakeidgen.impl
 
FlakeIdGeneratorService - Class in com.hazelcast.flakeidgen.impl
 
FlakeIdGeneratorService(NodeEngine) - Constructor for class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorService
 
FlatteningVisitor - Class in com.hazelcast.query.impl.predicates
Rewrites predicates: 1.
FlatteningVisitor() - Constructor for class com.hazelcast.query.impl.predicates.FlatteningVisitor
 
FLOAT_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
FLOAT_HUNDRED - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
FLOAT_SIZE_IN_BYTES - Static variable in class com.hazelcast.internal.nio.Bits
Float size in bytes
FloatArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.FloatArraySerializer
 
FLOATING_POINT_SUM - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
floatingPointSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
floatingPointSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
FloatingPointSumAggregator<I> - Class in com.hazelcast.aggregation.impl
 
FloatingPointSumAggregator() - Constructor for class com.hazelcast.aggregation.impl.FloatingPointSumAggregator
 
FloatingPointSumAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.FloatingPointSumAggregator
 
FloatSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.FloatSerializer
 
flush() - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
flush() - Method in class com.hazelcast.cp.internal.raft.impl.log.RaftLog
Flushes changes to persistent storage.
flush() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
flush() - Method in interface com.hazelcast.map.IMap
If this map has a MapStore, this method flushes all the local dirty entries.
FLUSH - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
flush(K, V, boolean) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
Flushes the supplied key to the map-store.
flush(WriteBehindQueue) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
Flushes supplied WriteBehindQueue to map-store.
flush(E) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
Flushes a key directly to map store.
flush(Data, Object, boolean) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
flush(Data, Object, boolean) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
flush() - Method in class com.hazelcast.map.impl.querycache.publisher.DefaultPublisherContext
 
flush() - Method in interface com.hazelcast.map.impl.querycache.publisher.PublisherContext
Flushes this publisher context.
FLUSH_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
flushAccumulator(PublisherContext, int) - Static method in class com.hazelcast.map.impl.querycache.publisher.AccumulatorSweeper
 
flushAllAccumulators(PublisherContext) - Static method in class com.hazelcast.map.impl.querycache.publisher.AccumulatorSweeper
 
flushedLogIndex(long) - Method in class com.hazelcast.cp.internal.raft.impl.state.LeaderState
 
flushedLogIndex() - Method in class com.hazelcast.cp.internal.raft.impl.state.LeaderState
 
flushLogs() - Method in class com.hazelcast.cp.internal.raft.impl.persistence.NopRaftStateStore
 
flushLogs() - Method in interface com.hazelcast.cp.internal.raft.impl.persistence.RaftStateStore
Forces all buffered (in any layer) Raft log changes to be written to the storage layer and returns after those changes are written.
flushMaps() - Method in interface com.hazelcast.map.impl.MapServiceContext
 
follower() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendFailureResponse
 
follower() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendSuccessResponse
 
FollowerState - Class in com.hazelcast.cp.internal.raft.impl.state
Mutable state maintained by the leader of the Raft group for each follower.
footprint() - Method in class com.hazelcast.internal.util.collection.OAHashSet
Returns the current memory consumption (in bytes)
footprint() - Method in class com.hazelcast.wan.impl.merkletree.ArrayMerkleTree
 
footprint() - Method in interface com.hazelcast.wan.impl.merkletree.MerkleTree
Returns the memory footprint of Merkle Tree in bytes
FORCE_DESTROY_RAFT_GROUP_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
forceCloseSession(String, long) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
forceCloseSession(String, long) - Method in interface com.hazelcast.cp.session.CPSessionManagementService
If a Hazelcast instance that owns a CP session crashes, its CP session is not terminated immediately.
FORCED_EVICTION_RETRY_COUNT - Static variable in class com.hazelcast.map.impl.operation.WithForcedEviction
 
forceDestroyCPGroup(String) - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Unconditionally destroys the given active CP group without using the Raft algorithm mechanics.
forceDestroyCPGroup(String) - Method in class com.hazelcast.cp.internal.RaftService
this method is idempotent
forceDestroyRaftGroup(String) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
ForceDestroyRaftGroupOp - Class in com.hazelcast.cp.internal.raftop.metadata
If a Raft node loses its majority completely, its remaining members cannot leave CP Subsystem gracefully.
ForceDestroyRaftGroupOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.ForceDestroyRaftGroupOp
 
ForceDestroyRaftGroupOp(String) - Constructor for class com.hazelcast.cp.internal.raftop.metadata.ForceDestroyRaftGroupOp
 
forceEvict(RecordStore) - Method in interface com.hazelcast.map.impl.eviction.Evictor
Evicts provided record-store forcibly.
forceEvict(RecordStore) - Method in class com.hazelcast.map.impl.eviction.EvictorImpl
 
forceLocalMemberToBeSafe(long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.PartitionServiceProxy
 
forceLocalMemberToBeSafe(long, TimeUnit) - Method in class com.hazelcast.internal.partition.PartitionServiceProxy
 
forceLocalMemberToBeSafe(long, TimeUnit) - Method in interface com.hazelcast.partition.PartitionService
Force the local member to be safe by checking and syncing partitions owned by the local member with at least one of the backups.
forceNext() - Method in class com.hazelcast.spi.impl.sequence.AbstractCallIdSequence
 
forceNext() - Method in interface com.hazelcast.spi.impl.sequence.CallIdSequence
Generates the next unique call ID.
forceNext() - Method in class com.hazelcast.spi.impl.sequence.CallIdSequenceWithoutBackpressure
 
forceRemoveRecord(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
forceSetTerminatedStatus() - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Sets node's status to RaftNodeStatus.TERMINATED unconditionally if it's not terminated or stepped down yet.
forceSetTerminatedStatus() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
forceStartBeforeJoin() - Method in interface com.hazelcast.internal.hotrestart.InternalHotRestartService
Executes force-start process, resets local hot restart data and member gets a new UUID.
forceStartBeforeJoin() - Method in class com.hazelcast.internal.hotrestart.NoopInternalHotRestartService
 
ForceStartNodeRequest - Class in com.hazelcast.internal.management.request
Request coming from Management Center to trigger a force start the node during hot-restart.
ForceStartNodeRequest() - Constructor for class com.hazelcast.internal.management.request.ForceStartNodeRequest
 
forceUnlock(K) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
forceUnlock(K) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
forceUnlock(NodeEngine, Data) - Method in class com.hazelcast.internal.locksupport.LockProxySupport
 
forceUnlock(Data) - Method in interface com.hazelcast.internal.locksupport.LockStore
Unlock the key regardless of the owner.
forceUnlock(Data) - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
forceUnlock(Data) - Method in class com.hazelcast.internal.locksupport.LockStoreProxy
 
forceUnlock() - Method in class com.hazelcast.internal.locksupport.operations.UnlockOperation
 
forceUnlock(K) - Method in interface com.hazelcast.map.IMap
Releases the lock for the specified key regardless of the lock owner.
forceUnlock(K) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
forceUnlock(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
forceUnlock(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
forceUnlock(Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
forceUnlock(K) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
forceUnlock(K) - Method in interface com.hazelcast.multimap.MultiMap
Releases the lock for the specified key regardless of the lock owner.
forEach(BiInt2ObjectMap.EntryConsumer<V>) - Method in class com.hazelcast.internal.util.collection.BiInt2ObjectMap
Iterate over the entries of the map
forEach(Consumer<V>) - Method in class com.hazelcast.internal.util.collection.BiInt2ObjectMap
Iterate over the values in the map
forEach(BiConsumer<? super Long, ? super Long>) - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
 
forEachKeyOfNode(int, Consumer<Object>) - Method in class com.hazelcast.wan.impl.merkletree.ArrayMerkleTree
 
forEachKeyOfNode(int, Consumer<Object>) - Method in interface com.hazelcast.wan.impl.merkletree.MerkleTree
Performs the given action for each key of the specified node until all elements have been processed or the action throws an exception.
forget(Xid) - Method in class com.hazelcast.client.impl.proxy.txn.xa.XAResourceProxy
 
forget(Xid) - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
 
forMap(IMap) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRequest
 
formatToString(boolean) - Method in class com.hazelcast.internal.partition.impl.MigrationStats
 
FRAGMENTATION_ID_OFFSET - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
FragmentedMigrationAwareService - Interface in com.hazelcast.spi.partition
FragmentedMigrationAwareService is an extension to the MigrationAwareService which allows migration/replication of partition replicas in smaller fragments.
Frame(byte[]) - Constructor for class com.hazelcast.client.impl.protocol.ClientMessage.Frame
 
Frame(byte[], int) - Constructor for class com.hazelcast.client.impl.protocol.ClientMessage.Frame
 
frameIterator() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
framesTransceived() - Method in class com.hazelcast.internal.networking.nio.NioThread
 
free(long, long) - Method in interface com.hazelcast.internal.memory.MemoryAllocator
Accepts the base address and size of a previously allocated block and sets it free.
FREE_MAX_PERCENTAGE_PROP - Static variable in class com.hazelcast.instance.impl.DefaultOutOfMemoryHandler
 
freePhysicalMemory() - Static method in class com.hazelcast.internal.memory.MemoryStatsSupport
Returns the amount of physical memory that is available on the system in bytes or -1 if not available.
freeSwapSpace() - Static method in class com.hazelcast.internal.memory.MemoryStatsSupport
Returns the amount of free swap space in bytes or -1 if not available.
from - Variable in class com.hazelcast.client.impl.protocol.codec.ListSubCodec.RequestParameters
Low endpoint (inclusive) of the subList
from(T) - Static method in class com.hazelcast.internal.cluster.impl.ClusterStateChange
 
from(Member) - Static method in class com.hazelcast.internal.partition.PartitionReplica
 
from(Member[]) - Static method in class com.hazelcast.internal.partition.PartitionReplica
 
fromFlags(int) - Static method in enum com.hazelcast.internal.nio.Packet.Type
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.AliasedDiscoveryConfigDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.ClientBwListDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.ClientBwListEntryDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.ClientEndPointDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.ClusterHotRestartStatusDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.ConnectionManagerDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.CustomWanPublisherConfigDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.DiscoveryConfigDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.DiscoveryStrategyConfigDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.EventServiceDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.ManagedExecutorDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.MapConfigDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.OperationServiceDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.PartitionServiceBeanDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.PermissionConfigDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.ProxyServiceDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.SlowOperationDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.SlowOperationInvocationDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.WanBatchReplicationPublisherConfigDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.WanConsumerConfigDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.WanReplicationConfigDTO
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.dto.WanSyncConfigDTO
 
fromJson(JsonObject) - Method in interface com.hazelcast.internal.management.JsonSerializable
Extracts the state from the given json object and mutates the state of this object.
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.ChangeClusterStateRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.ChangeWanStateRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.ClearWanQueuesRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.ClusterPropsRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.ConsoleCommandRequest
 
fromJson(JsonObject) - Method in interface com.hazelcast.internal.management.request.ConsoleRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.ExecuteScriptRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.ForceStartNodeRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.GetClusterStateRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.GetMapEntryRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.GetMemberSystemPropertiesRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.MapConfigRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.MemberConfigRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.PromoteMemberRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.RunGcRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.ShutdownClusterRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.ThreadDumpRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.TriggerPartialStartRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.UpdatePermissionConfigRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.request.WanCheckConsistencyRequest
 
fromJson(JsonObject) - Method in class com.hazelcast.internal.management.TimedMemberState
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.HotRestartStateImpl
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.LocalFlakeIdGeneratorStatsImpl
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.LocalOperationStatsImpl
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.LocalPNCounterStatsImpl
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.LocalTopicStatsImpl
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.LocalWanStatsImpl
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.MemberPartitionStateImpl
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.NodeStateImpl
 
fromJson(JsonObject) - Method in class com.hazelcast.monitor.impl.WanSyncStateImpl
 
fromJsonObject(JsonObject) - Static method in class com.hazelcast.internal.util.JsonUtil
Transforms the provided JsonObject int a map of name/value pairs.
fromMap(Map<String, String>) - Static method in class com.hazelcast.client.impl.protocol.util.PropertiesUtil
 
fromSequence - Variable in class com.hazelcast.client.impl.protocol.codec.MetricsReadMetricsCodec.RequestParameters
The sequence the recorded metrics should be read starting with.
fromStoreValue(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
fromString(String) - Static method in enum com.hazelcast.internal.networking.nio.SelectorMode
 
fromValue(int) - Static method in enum com.hazelcast.cp.internal.datastructures.atomiclong.operation.AlterOp.AlterResultType
 
fromValue(int) - Static method in enum com.hazelcast.cp.internal.datastructures.atomicref.operation.ApplyOp.ReturnValueType
 
function - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongAlterCodec.RequestParameters
The function applied to the currently stored value.
function - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongApplyCodec.RequestParameters
The function applied to the value and the value is not changed.
function - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefApplyCodec.RequestParameters
The function applied to the value.
FunctionEx<T,R> - Interface in com.hazelcast.internal.util.function
Serializable variant of java.util.function.Function which declares checked exception.
Functions - Class in com.hazelcast.internal.util.function
Factory methods for several common functions.
FutureUtil - Class in com.hazelcast.internal.util
This utility class contains convenience methods to work with multiple futures at the same time, e.g.
FutureUtil.ExceptionHandler - Interface in com.hazelcast.internal.util
Internally used interface to define behavior of the FutureUtil methods when exceptions arise
FutureUtilExceptionHandler - Class in com.hazelcast.spi.impl.eventservice.impl
Exception handler which logs the FutureUtilExceptionHandler.message in case the exception is a MemberLeftException, otherwise wraps the exception in a HazelcastException and rethrows it.
FutureUtilExceptionHandler(ILogger, String) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.FutureUtilExceptionHandler
 

G

GarbageCollectionMetricSet - Class in com.hazelcast.internal.metrics.metricsets
A metrics set for exposing GarbageCollectorMXBean metrics.
GarbageCollectorStats - Interface in com.hazelcast.internal.memory
Garbage collector statistics for the JVM which current HazelcastInstance belongs to.
Gauge - Interface in com.hazelcast.internal.metrics
A Gauge is a Metric where a particular value is read instantaneously.
GCP_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
GcpConfig - Class in com.hazelcast.config
Configuration for the GCP Discovery Strategy.
GcpConfig() - Constructor for class com.hazelcast.config.GcpConfig
 
GcpConfig(GcpConfig) - Constructor for class com.hazelcast.config.GcpConfig
 
GCStatsSupport - Class in com.hazelcast.internal.memory
Used to gather garbage collection statistics.
generate(ClientConfig) - Static method in class com.hazelcast.client.config.ClientConfigXmlGenerator
Convenience for ClientConfigXmlGenerator.generate(ClientConfig, int), which generates the xml without any formatting.
generate(ClientConfig, int) - Static method in class com.hazelcast.client.config.ClientConfigXmlGenerator
Transforms the given ClientConfig to xml string formatting the output with given indent, -1 means no formatting.
generate(Config) - Method in class com.hazelcast.config.ConfigXmlGenerator
Generates the XML string based on some Config.
GENERATE_THREAD_ID_OP - Static variable in class com.hazelcast.cp.internal.session.RaftSessionServiceDataSerializerHook
 
Generated - Annotation Type in com.hazelcast.client.impl.protocol
Indicates that the source code is auto generated by the Hazelcast Client Protocol Code Generator.
GeneratedBuildProperties - Class in com.hazelcast.instance
This class is generated in a build-time from a template stored at src/main/template/com/hazelcast/instance/GeneratedBuildProperties.
generateInterceptorId(String, MapInterceptor) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
 
generateThreadId(RaftGroupId) - Method in class com.hazelcast.client.cp.internal.session.ClientProxySessionManager
 
generateThreadId(RaftGroupId) - Method in class com.hazelcast.cp.internal.session.AbstractProxySessionManager
Generates a cluster-wide unique thread id for the caller
generateThreadId(RaftGroupId) - Method in class com.hazelcast.cp.internal.session.ProxySessionManagerService
 
generateThreadId(CPGroupId) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
GenerateThreadIdMessageTask - Class in com.hazelcast.cp.internal.session.client
Client message task for GenerateThreadIdOp
GenerateThreadIdMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.session.client.GenerateThreadIdMessageTask
 
GenerateThreadIdOp - Class in com.hazelcast.cp.internal.session.operation
Operation for generating a cluster-wide unique thread id for the caller.
GenerateThreadIdOp() - Constructor for class com.hazelcast.cp.internal.session.operation.GenerateThreadIdOp
 
generateXml(ConfigXmlGenerator.XmlGenerator, List<IndexConfig>) - Static method in class com.hazelcast.query.impl.IndexUtils
 
GENERIC_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
 
GENERIC_OPERATION_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
The number of generic operation handler threads per member.
GENERIC_PARTITION_ID - Static variable in class com.hazelcast.spi.impl.operationservice.Operation
Marks an Operation as non-partition-specific.
GenericOperation - Class in com.hazelcast.ringbuffer.impl.operations
Ring buffer operations which don't need to send any parameters and which can be determined by only sending the operation type which is a byte of information.
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.impl
An OperationThread for non partition specific operations.
GenericOperationThread(String, int, OperationQueue, ILogger, NodeExtension, OperationRunner, boolean, ClassLoader) - Constructor for class com.hazelcast.spi.impl.operationexecutor.impl.GenericOperationThread
 
geQueryCacheConfigurator() - Method in class com.hazelcast.map.impl.querycache.subscriber.AbstractSubscriberContext
 
geQueryCacheConfigurator() - Method in interface com.hazelcast.map.impl.querycache.subscriber.SubscriberContext
Returns QueryCacheConfigurator for this context.
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(K) - Method in class com.hazelcast.cache.impl.CacheProxy
 
get(K, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.CacheProxy
 
get(SerializationService) - Method in class com.hazelcast.cache.impl.DeferredValue
 
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() - Method in class com.hazelcast.cache.impl.operation.AddCacheConfigOperationSupplier
 
get(K) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
get(K, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
get() - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
get() - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
get() - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
get(long, TimeUnit) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
get() - Method in class com.hazelcast.client.impl.ClientInterceptingDelegatingFuture
 
get(long, TimeUnit) - Method in class com.hazelcast.client.impl.ClientInterceptingDelegatingFuture
 
get() - Method in class com.hazelcast.client.impl.CollectRemoteTransactionsOperationSupplier
 
get - Variable in class com.hazelcast.client.impl.protocol.codec.CachePutCodec.RequestParameters
boolean flag indicating if the previous value should be retrieved.
get() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxiesMessageTask
 
get() - Method in class com.hazelcast.client.impl.protocol.task.DeployClassesMessageTask
 
get(int) - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
get(Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
get(K) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
get() - Method in class com.hazelcast.client.impl.proxy.ClientPNCounterProxy
 
get(Object) - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
get() - Method in class com.hazelcast.client.impl.proxy.ClientScheduledFutureProxy
 
get(long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledFutureProxy
 
get(Object) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
get(K) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMultiMapProxy
 
get() - Method in class com.hazelcast.client.impl.spi.impl.ClientResponseHandlerSupplier
 
get(int) - Method in class com.hazelcast.collection.impl.list.ListContainer
 
get(int) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
 
get(String) - Static method in enum com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
 
get() - Method in interface com.hazelcast.cp.IAtomicLong
Gets the current value.
get() - Method in interface com.hazelcast.cp.IAtomicReference
Gets the current value.
get() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLong
 
get() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
get() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRef
 
get() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
get() - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValue
 
get() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Returns the current value of the counter.
get(K) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
get(K) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
get(K) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
get(K) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
get(K) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
get(String, String) - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
get(String, String) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
get(VectorClock) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterImpl
Returns the current value of the counter.
get() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterProxy
 
get() - Method in class com.hazelcast.internal.dynamicconfig.AddDynamicConfigOperationSupplier
 
get(Object) - Method in class com.hazelcast.internal.dynamicconfig.AggregatingMap
 
get() - Method in class com.hazelcast.internal.jmx.suppliers.LocalMapStatsSupplier
 
get() - Method in class com.hazelcast.internal.jmx.suppliers.LocalMultiMapStatsSupplier
 
get() - Method in class com.hazelcast.internal.jmx.suppliers.LocalQueueStatsSupplier
 
get() - Method in class com.hazelcast.internal.jmx.suppliers.LocalReplicatedMapStatsSupplier
 
get() - Method in interface com.hazelcast.internal.jmx.suppliers.StatsSupplier
 
get(int) - Method in class com.hazelcast.internal.json.JsonArray
Returns the value of the element at the specified position in this array.
get(String) - Method in class com.hazelcast.internal.json.JsonObject
Returns the value of the member with the specified name in this object.
get() - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
get() - Method in class com.hazelcast.internal.longregister.LongRegister
 
GET - Static variable in class com.hazelcast.internal.longregister.LongRegisterDataSerializerHook
 
get() - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
get(S) - Method in interface com.hazelcast.internal.metrics.DoubleProbeFunction
Gets the current value of the source object.
get(S) - Method in interface com.hazelcast.internal.metrics.LongProbeFunction
Gets the current value of the source object as a long.
get(long) - Method in class com.hazelcast.internal.metrics.managementcenter.ConcurrentArrayRingbuffer
 
get(K) - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
get(K) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
get(K) - Method in interface com.hazelcast.internal.nearcache.NearCache
Gets the value associated with the given key.
get(K) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
Gets the value associated with the given key.
get() - Method in class com.hazelcast.internal.networking.nio.NioOutboundPipeline
 
get() - Method in class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolThreadLocal
 
get(int, int) - Method in class com.hazelcast.internal.util.collection.BiInt2ObjectMap
Retrieve a value from the map.
get(K1, K2) - Method in class com.hazelcast.internal.util.collection.ComposedKeyMap
 
get(Object) - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
 
get(int) - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
Overloaded version of Map.get(Object) that takes a primitive int key.
get(K) - Method in class com.hazelcast.internal.util.collection.InternalListMultiMap
Return collection of values associated with a given key
get(K) - Method in class com.hazelcast.internal.util.collection.InternalSetMultimap
Return Set of values associated with a given key
get(long) - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
 
get(Object) - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
 
get(long) - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
 
get(long) - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
 
get(Object) - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
 
get(long) - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
Overloaded version of Map.get(Object) that takes a primitive long key.
get(Object) - Method in class com.hazelcast.internal.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.internal.util.counters.Counter
Gets the current value of the counter.
get() - Method in class com.hazelcast.internal.util.counters.MwCounter
 
get() - Method in interface com.hazelcast.internal.util.function.SupplierEx
 
get(long, int) - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray12byteKey
Returns the address of the value block mapped by (key1, key2).
get(long, long) - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray16byteKey
Returns the address of the value block mapped by (key1, key2).
get(long) - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray8byteKey
Returns the address of the value block mapped by the given key.
get(long, int) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray12byteKeyImpl
 
get(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyImpl
 
get(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyNoValue
 
get(long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray8byteKeyImpl
 
get(T) - Method in class com.hazelcast.internal.util.ItemCounter
Get current counter for an item item
get() - Static method in class com.hazelcast.internal.util.RuntimeAvailableProcessors
Returns the number of available processors.
get(K) - Method in interface com.hazelcast.internal.util.scheduler.EntryTaskScheduler
Return the entry for the scheduled key.
get(K) - Method in class com.hazelcast.internal.util.scheduler.SecondsBasedEntryTaskScheduler
 
get() - Static method in class com.hazelcast.internal.util.ThreadLocalRandomProvider
Returns the current thread's Random.
get(int) - Method in class com.hazelcast.json.internal.JsonPattern
 
get(Object) - Method in interface com.hazelcast.map.BaseMap
Returns the value for the specified key, or null if this map does not contain this key.
get(Object) - Method in interface com.hazelcast.map.IMap
Returns the value for the specified key, or null if this map does not contain this key.
GET - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
get() - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperationSupplier
 
get() - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperationSupplier
 
get(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
get(Class<? extends Result>) - Method in class com.hazelcast.map.impl.query.ResultProcessorRegistry
 
get(long) - Method in interface com.hazelcast.map.impl.querycache.accumulator.CyclicBuffer
Returns the element in this buffer which has the supplied sequence.
get(long) - Method in class com.hazelcast.map.impl.querycache.accumulator.DefaultCyclicBuffer
 
get(Object) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
get(Data) - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordStore
 
get(Data, boolean, Address) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
get(Data, boolean, Address) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Gets record from RecordStore.
get(K) - Method in interface com.hazelcast.map.impl.recordstore.Storage
 
get(Data) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
get(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
get(Object, boolean) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
get(Object) - Method in interface com.hazelcast.map.QueryCache
 
get(K) - Method in interface com.hazelcast.multimap.BaseMultiMap
Returns the collection of values associated with the key.
GET - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
get(K) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
get(K) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
 
get(K) - Method in interface com.hazelcast.multimap.MultiMap
Returns the collection of values associated with the key.
get(byte) - Static method in enum com.hazelcast.nio.serialization.FieldType
 
get(String) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
 
get(String) - Method in class com.hazelcast.query.impl.ConverterCache
 
get(String) - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
get(String) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
GET - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
get(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
get(Object) - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
 
get(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
get(Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
get(int) - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
 
get(int) - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
 
get(int) - Method in interface com.hazelcast.ringbuffer.ReadResultSet
Gets the item at the given index.
get() - Method in class com.hazelcast.scheduledexecutor.impl.DelegatingScheduledFutureStripper
 
get(long, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.DelegatingScheduledFutureStripper
 
get(String) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
get() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledFutureProxy
 
get(long, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledFutureProxy
 
get(int) - Method in interface com.hazelcast.security.Parameters
 
get() - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
get(long, TimeUnit) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
get() - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
get(long, TimeUnit) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
get() - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
get(long, TimeUnit) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
get() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.DeregistrationOperationSupplier
 
get() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.RegistrationOperationSupplier
 
get() - Method in class com.hazelcast.spi.impl.operationservice.impl.InboundResponseHandlerSupplier
 
get(long) - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
Gets the invocation for the given call ID.
get() - Method in class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectFuture
 
get(int) - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
 
get(String) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the value for the given key.
get(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
get(Object, Class<T>) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
get(Object, Callable<T>) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
get(Object) - Method in class com.hazelcast.transaction.impl.SuspendedTransaction
 
get(Object) - Method in interface com.hazelcast.transaction.impl.Transaction
 
get(Object) - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
get(Object) - Method in class com.hazelcast.transaction.impl.TransactionLog
 
get(Object) - Method in class com.hazelcast.transaction.impl.xa.XATransaction
 
get(Object) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.get(Object).
get(K) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
Returns the collection of values associated with the key.
get0(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
GET_ACTIVE_CP_MEMBERS_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
GET_ACTIVE_RAFT_GROUP_BY_NAME_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
GET_ACTIVE_RAFT_GROUP_IDS_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
GET_ALL - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
GET_ALL - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
GET_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
GET_ALL_FACTORY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
GET_ALL_SCHEDULED_ON_MEMBER - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
GET_ALL_SCHEDULED_ON_PARTITION - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
GET_ALL_SCHEDULED_ON_PARTITION_OPERATION_FACTORY - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
GET_AND_ADD - Static variable in class com.hazelcast.internal.longregister.LongRegisterDataSerializerHook
 
GET_AND_ADD_OP - Static variable in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongDataSerializerHook
 
GET_AND_REMOVE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
GET_AND_REPLACE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
GET_AND_SET - Static variable in class com.hazelcast.internal.longregister.LongRegisterDataSerializerHook
 
GET_AND_SET_OP - Static variable in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongDataSerializerHook
 
GET_CACHE_ENTRY_VIEW_PROCESSOR - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
GET_CACHE_TIME_TAKEN_NANOS - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
GET_CONFIG - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
GET_CONNECTED_CLIENTS - Static variable in class com.hazelcast.client.impl.ClientDataSerializerHook
 
GET_COUNT_OP - Static variable in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchDataSerializerHook
 
GET_DELAY_OP - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
GET_DESTROYING_RAFT_GROUP_IDS_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
GET_ENTRY_VIEW - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
GET_INITIAL_RAFT_GROUP_MEMBERS_IF_CURRENT_GROUP_MEMBER_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
GET_LEADED_GROUPS - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
GET_MEMBERSHIP_CHANGE_SCHEDULE_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
GET_OP - Static variable in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefDataSerializerHook
 
GET_RAFT_GROUP_IDS_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
GET_RAFT_GROUP_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
GET_RAFT_LOCK_OWNERSHIP_STATE_OP - Static variable in class com.hazelcast.cp.internal.datastructures.lock.LockDataSerializerHook
 
GET_RESULT - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
GET_ROUND_OP - Static variable in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchDataSerializerHook
 
GET_SESSIONS_OP - Static variable in class com.hazelcast.cp.internal.session.RaftSessionServiceDataSerializerHook
 
GET_STATS_OP - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
getAcceptableHeartbeatPauseMillis() - Method in class com.hazelcast.splitbrainprotection.impl.ProbabilisticSplitBrainProtectionFunction
 
getAccessHit() - Method in interface com.hazelcast.cache.CacheEntryView
Gets the count of how many time this cache entry has been accessed.
getAccessHit() - Method in class com.hazelcast.cache.impl.CacheEventContext
 
getAccessHit() - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
 
getAccessHit() - Method in class com.hazelcast.cache.impl.merge.entry.LazyCacheEntryView
 
getAccessHit() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
getAccessHit() - Method in interface com.hazelcast.internal.eviction.Evictable
Gets the access hit count of this Evictable.
getAccessHit() - Method in interface com.hazelcast.internal.eviction.EvictableEntryView
Gets the access hit count of this EvictableEntryView.
getAccessHit() - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.CacheBrowserEntryView
 
getAccessHit() - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
getAccessHit() - Method in class com.hazelcast.internal.nearcache.impl.store.HeapNearCacheRecordMap.NearCacheEvictableSamplingEntry
 
getAccessKey() - Method in class com.hazelcast.config.AwsConfig
getAccessor() - Method in interface com.hazelcast.internal.eviction.EvictionCandidate
The accessor (key or ID) of Evictable entry or record or whatever.
getAccessor() - Method in class com.hazelcast.internal.memory.impl.MemoryManagerBean
 
getAccessor() - Method in interface com.hazelcast.internal.memory.MemoryManager
 
getAccessor() - Method in class com.hazelcast.internal.nearcache.impl.store.HeapNearCacheRecordMap.NearCacheEvictableSamplingEntry
 
getAccessor() - Method in class com.hazelcast.internal.util.collection.HsaHeapMemoryManager
 
getAccumulatorInfoOrNull(String, String) - Method in interface com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfoSupplier
Returns AccumulatorInfo for cache of maIMapp.
getAccumulatorInfoOrNull(String, String) - Method in class com.hazelcast.map.impl.querycache.accumulator.DefaultAccumulatorInfoSupplier
 
getAccumulatorInfoSupplier() - Method in class com.hazelcast.map.impl.querycache.publisher.DefaultPublisherContext
 
getAccumulatorInfoSupplier() - Method in interface com.hazelcast.map.impl.querycache.publisher.PublisherContext
Returns AccumulatorInfoSupplier for this context.
getAccumulatorInfoSupplier() - Method in class com.hazelcast.map.impl.querycache.subscriber.AbstractSubscriberContext
 
getAccumulatorInfoSupplier() - Method in interface com.hazelcast.map.impl.querycache.subscriber.SubscriberContext
Returns AccumulatorInfoSupplier for this context.
getAccumulatorOrNull(QueryCacheContext, String, String, int) - Static method in class com.hazelcast.map.impl.querycache.utils.QueryCacheUtil
Returns Accumulator of a partition.
getAccumulatorRegistryOrNull(QueryCacheContext, String, String) - Static method in class com.hazelcast.map.impl.querycache.utils.QueryCacheUtil
Returns PartitionAccumulatorRegistry of a QueryCache.
getAccumulators(QueryCacheContext, String, String) - Static method in class com.hazelcast.map.impl.querycache.utils.QueryCacheUtil
Returns accumulators of a QueryCache.
getAcknowledgeType() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the strategy for when the target cluster should acknowledge that a WAN event batch has been processed.
getAcquireTime() - Method in interface com.hazelcast.internal.locksupport.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.ConfigPermission
 
getActions() - Method in class com.hazelcast.security.permission.InstancePermission
 
getActions() - Method in class com.hazelcast.security.permission.TransactionPermission
 
getActiveAndMissingMembers() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getActiveConnection(Address) - Method in interface com.hazelcast.client.impl.connection.ClientConnectionManager
 
getActiveConnection(Address) - Method in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
getActiveConnectionCount() - Method in class com.hazelcast.internal.jmx.NetworkingServiceMBean
 
getActiveConnections() - Method in interface com.hazelcast.client.impl.connection.ClientConnectionManager
 
getActiveConnections() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
getActiveConnections() - Method in interface com.hazelcast.internal.nio.AggregateEndpointManager
Returns all active connections from the underlying EndpointManagers.
getActiveConnections() - Method in class com.hazelcast.internal.nio.DefaultAggregateEndpointManager
 
getActiveConnections() - Method in interface com.hazelcast.internal.nio.EndpointManager
Returns all connections bind or not that are currently holding resources on this member.
getActiveConnections() - Method in class com.hazelcast.internal.nio.tcp.ClientViewUnifiedEndpointManager
 
getActiveConnections() - Method in class com.hazelcast.internal.nio.tcp.MemberViewUnifiedEndpointManager
 
getActiveConnections() - Method in class com.hazelcast.internal.nio.tcp.TcpIpEndpointManager
 
getActiveConnections() - Method in class com.hazelcast.internal.nio.tcp.TextViewUnifiedEndpointManager
 
getActiveConnections() - Method in class com.hazelcast.internal.nio.UnifiedAggregateEndpointManager
 
GetActiveCPMembersOp - Class in com.hazelcast.cp.internal.raftop.metadata
Returns the current active CP members in the Metadata group.
GetActiveCPMembersOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.GetActiveCPMembersOp
 
getActiveGroup(String) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
getActiveGroupIds() - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
getActivelyAttachedSessions() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatch
 
getActivelyAttachedSessions() - Method in class com.hazelcast.cp.internal.datastructures.lock.Lock
Returns session id of the current lock holder or an empty collection if the lock is not held
getActivelyAttachedSessions() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.Semaphore
 
getActivelyAttachedSessions() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.BlockingResource
Returns a non-null collection of session ids that the current state of the resource is attached to.
getActiveMemberNetworkConfig(Config) - Static method in class com.hazelcast.config.ConfigAccessor
 
getActiveMembers() - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
getActiveMigration() - Method in class com.hazelcast.internal.partition.PartitionRuntimeState
 
getActivePartitionCount() - Method in class com.hazelcast.internal.jmx.PartitionServiceMBean
 
getActivePartitionCount() - Method in class com.hazelcast.internal.management.dto.PartitionServiceBeanDTO
 
getActivePublisherName() - Method in class com.hazelcast.monitor.impl.WanSyncStateImpl
 
getActivePublisherName() - Method in interface com.hazelcast.monitor.WanSyncState
 
GetActiveRaftGroupByNameOp - Class in com.hazelcast.cp.internal.raftop.metadata
Returns an active CP group by its name
GetActiveRaftGroupByNameOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.GetActiveRaftGroupByNameOp
 
GetActiveRaftGroupByNameOp(String) - Constructor for class com.hazelcast.cp.internal.raftop.metadata.GetActiveRaftGroupByNameOp
 
GetActiveRaftGroupIdsOp - Class in com.hazelcast.cp.internal.raftop.metadata
Returns ids of the active Raft groups.
GetActiveRaftGroupIdsOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.GetActiveRaftGroupIdsOp
 
getActiveRegistrations(UUID) - Method in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
getActiveWanConfigName() - Method in class com.hazelcast.monitor.impl.WanSyncStateImpl
 
getActiveWanConfigName() - Method in interface com.hazelcast.monitor.WanSyncState
 
getActualDelayMillis() - Method in class com.hazelcast.internal.util.scheduler.ScheduledEntry
 
getActualDelaySeconds() - Method in class com.hazelcast.internal.util.scheduler.ScheduledEntry
 
getAddedPublisherIds() - Method in class com.hazelcast.wan.impl.AddWanConfigResult
Returns the IDs for the WAN publishers which were added to the configuration.
getAddress() - Method in class com.hazelcast.client.impl.protocol.task.AbstractAddressMessageTask
 
getAddress() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetConfigMessageTask
 
getAddress() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterAddMessageTask
 
getAddress() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetMessageTask
 
getAddress() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnAddressMessageTask
 
getAddress() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToAddressMessageTask
 
getAddress() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromAddressMessageTask
 
getAddress() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromAddressMessageTask
 
getAddress() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromAddressMessageTask
 
getAddress() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromAddressMessageTask
 
getAddress() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromAddressMessageTask
 
getAddress() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromAddressMessageTask
 
getAddress() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromAddressMessageTask
 
getAddress() - Method in class com.hazelcast.cluster.impl.AbstractMember
 
getAddress() - Method in interface com.hazelcast.cluster.Member
Returns the Address of this Member.
getAddress() - Method in class com.hazelcast.config.VaultSecureStoreConfig
Returns the Vault server address.
getAddress() - Method in interface com.hazelcast.cp.CPMember
Returns the address of this CP member.
getAddress() - Method in class com.hazelcast.cp.internal.CPMemberInfo
 
getAddress() - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
 
getAddress() - Method in class com.hazelcast.internal.cluster.MemberInfo
 
getAddress() - Method in class com.hazelcast.internal.util.AddressUtil.AddressHolder
 
getAddress() - Method in class com.hazelcast.internal.util.AddressUtil.AddressMatcher
 
getAddress() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
getAddress() - Method in interface com.hazelcast.monitor.MemberState
 
getAddress() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
 
getAddress() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Returns the address of the member the task is associated with.
getAddresses() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the list of candidate addresses that client will use to establish initial connection
getAddresses() - Method in class com.hazelcast.internal.cluster.impl.MembersView
 
getAddressHolder(String) - Static method in class com.hazelcast.internal.util.AddressUtil
 
getAddressHolder(String, int) - Static method in class com.hazelcast.internal.util.AddressUtil
 
getAddressMap() - Method in class com.hazelcast.cluster.impl.AbstractMember
 
getAddressMap() - Method in interface com.hazelcast.cluster.Member
 
getAddressMap() - Method in class com.hazelcast.internal.cluster.MemberInfo
 
getAddressMatcher(String) - Static method in class com.hazelcast.internal.util.AddressUtil
Gets an AddressMatcher for a given addresses.
getAddressProvider() - Method in class com.hazelcast.client.impl.clientside.CandidateClusterContext
 
getAdjustedTTLSeconds(int) - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
getAdjustedTTLSeconds(int) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
getAdvancedNetworkConfig() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getAdvancedNetworkConfig() - Method in class com.hazelcast.config.Config
 
getAdvancedNetworkConfig() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getAggregateEndpointManager() - Method in interface com.hazelcast.internal.nio.NetworkingService
Return an aggregate endpoint which acts as a view of all endpoints merged together for reporting purposes eg.
getAggregateEndpointManager() - Method in class com.hazelcast.internal.nio.tcp.TcpIpNetworkingService
The aggregate endpoint manager acts as a composite of all configured endpoints.
getAggregator() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
 
getAggregator() - Method in class com.hazelcast.client.impl.protocol.task.map.DefaultMapProjectMessageTask
 
getAggregator() - Method in class com.hazelcast.client.impl.protocol.task.map.DefaultMapQueryMessageTask
 
getAggregator() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateMessageTask
 
getAggregator() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateWithPredicateMessageTask
 
getAggregator() - Method in class com.hazelcast.map.impl.query.AggregationResult
 
getAggregator() - Method in class com.hazelcast.map.impl.query.Query
 
getAlgorithm() - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
Returns the encryption algorithm.
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<? extends K>, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.CacheProxy
 
getAll(Set<Data>, ExpiryPolicy) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Gets a collection of entries from the store, returning them as Map of the values associated with the set of keys requested.
getAll(Set<? extends K>) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
getAll(Set<? extends K>, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
getAll(Set<K>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
getAll() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
getAll(Set<K>) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
getAll(Set<K>) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
getAll(Set<K>) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
getAll(Set<K>) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
getAll(Set<K>) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
getAll(String, Set<String>) - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
getAll(String, Set<String>) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
getAll(Set<K>) - Method in interface com.hazelcast.map.IMap
Returns an immutable map of entries for the given keys.
getAll(Set<K>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
getAll() - Method in interface com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfoSupplier
 
getAll() - Method in class com.hazelcast.map.impl.querycache.accumulator.DefaultAccumulatorInfoSupplier
 
getAll() - Method in class com.hazelcast.map.impl.querycache.publisher.MapListenerRegistry
 
getAll() - Method in class com.hazelcast.map.impl.querycache.publisher.MapPublisherRegistry
 
getAll() - Method in class com.hazelcast.map.impl.querycache.publisher.PartitionAccumulatorRegistry
 
getAll() - Method in class com.hazelcast.map.impl.querycache.publisher.PublisherRegistry
 
getAll() - Method in class com.hazelcast.map.impl.querycache.publisher.QueryCacheListenerRegistry
 
getAll() - Method in interface com.hazelcast.map.impl.querycache.Registry
Returns map of all registered items in this registry.
getAll() - Method in class com.hazelcast.map.impl.querycache.subscriber.MapSubscriberRegistry
 
getAll(Set) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
getAll() - Method in class com.hazelcast.map.impl.querycache.subscriber.SubscriberRegistry
 
getAll(Set<Data>, Address) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
getAll(Set<Data>, Address) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
getAll(Set<K>) - Method in interface com.hazelcast.map.QueryCache
 
getAllCPGroupIds() - Method in class com.hazelcast.cp.internal.RaftService
 
getAllDiscoveryConfigs() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
getAllDistributedObjects() - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
 
getAllDistributedObjects() - Method in interface com.hazelcast.spi.impl.proxyservice.ProxyService
 
getAllDone(Collection<Future>) - Static method in class com.hazelcast.internal.util.FutureUtil
Get all futures that are done
getAllHazelcastClients() - Static method in class com.hazelcast.client.HazelcastClient
Gets an immutable collection of all client HazelcastInstances created in this JVM.
getAllHazelcastInstances() - Static method in class com.hazelcast.core.Hazelcast
Returns all active/running HazelcastInstances on this JVM.
getAllHazelcastInstances() - Static method in class com.hazelcast.instance.impl.HazelcastInstanceFactory
 
getAllHazelcastInstances() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Gets all active/running HazelcastOSGiInstances on the owner bundle.
getAllInterfaces(Class<?>) - Static method in class com.hazelcast.internal.nio.ClassLoaderUtil
 
getAllInternal(Set<? extends K>, Collection<Data>, ExpiryPolicy, List<Object>, long) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
getAllInternal(Set<K>, Map<Integer, List<Data>>, List<Object>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
getAllInternal(Set<K>, Map<Integer, List<Data>>, List<Object>) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
getAllInternal(Set<K>, List<Data>, List<Object>) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
getAllInternal(Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
getAllLocks() - Method in interface com.hazelcast.internal.locksupport.LockSupportService
 
getAllLocks() - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
getAllNamespaces(int) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
 
getAllNamespaces(int) - Method in class com.hazelcast.internal.locksupport.LockStoreContainer
 
getAllNamespaces(int) - Method in class com.hazelcast.map.impl.PartitionContainer
 
getAllNamespaces(int) - Method in class com.hazelcast.multimap.impl.MultiMapPartitionContainer
 
getAllocator() - Method in class com.hazelcast.internal.memory.impl.MemoryManagerBean
 
getAllocator() - Method in interface com.hazelcast.internal.memory.MemoryManager
 
getAllocator() - Method in class com.hazelcast.internal.util.collection.HsaHeapMemoryManager
 
getAllocatorType() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns the NativeMemoryConfig.MemoryAllocatorType to be used while allocating native memory.
GetAllOperation - Class in com.hazelcast.map.impl.operation
 
GetAllOperation() - Constructor for class com.hazelcast.map.impl.operation.GetAllOperation
 
GetAllOperation(String, List<Data>) - Constructor for class com.hazelcast.map.impl.operation.GetAllOperation
 
GetAllOperation - Class in com.hazelcast.multimap.impl.operations
 
GetAllOperation() - Constructor for class com.hazelcast.multimap.impl.operations.GetAllOperation
 
GetAllOperation(String, Data) - Constructor for class com.hazelcast.multimap.impl.operations.GetAllOperation
 
getAllRaftNodes() - Method in class com.hazelcast.cp.internal.RaftService
 
getAllRecordStores() - Method in class com.hazelcast.map.impl.PartitionContainer
 
getAllReplicatedRecordStores(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
getAllScheduledFutures() - Method in class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
getAllScheduledFutures() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
getAllScheduledFutures() - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Fetches and returns all scheduled (not disposed yet) futures from all members in the cluster.
GetAllScheduledOnMemberOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
GetAllScheduledOnMemberOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnMemberOperation
 
GetAllScheduledOnMemberOperation(String) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnMemberOperation
 
GetAllScheduledOnPartitionOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
GetAllScheduledOnPartitionOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnPartitionOperation
 
GetAllScheduledOnPartitionOperation(String) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnPartitionOperation
 
GetAllScheduledOnPartitionOperationFactory - Class in com.hazelcast.scheduledexecutor.impl.operations
 
GetAllScheduledOnPartitionOperationFactory() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnPartitionOperationFactory
 
GetAllScheduledOnPartitionOperationFactory(String) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnPartitionOperationFactory
 
getAllServiceNamespaces(PartitionReplicationEvent) - Method in class com.hazelcast.cache.impl.CacheService
 
getAllServiceNamespaces(PartitionReplicationEvent) - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
getAllServiceNamespaces(PartitionReplicationEvent) - Method in class com.hazelcast.map.impl.MapService
 
getAllServiceNamespaces(PartitionReplicationEvent) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
getAllServiceNamespaces(PartitionReplicationEvent) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
getAllServiceNamespaces(PartitionReplicationEvent) - Method in class com.hazelcast.spi.impl.CountingMigrationAwareService
 
getAllServiceNamespaces(PartitionReplicationEvent) - Method in interface com.hazelcast.spi.partition.FragmentedMigrationAwareService
Returns all known namespaces for given replication event.
getAllSessions(String) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
getAllSessions(CPGroupId) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
getAllSessions(String) - Method in interface com.hazelcast.cp.session.CPSessionManagementService
Returns a non-null collection of CP sessions that are currently active in the given CP group.
getAllThreads() - Static method in class com.hazelcast.internal.management.ThreadDumpGenerator
 
getAllWaitKeys() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.BlockingResource
 
getAnchor() - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
 
getAnchor() - Method in interface com.hazelcast.query.PagingPredicate
Retrieve the anchor object which is the last value object on the previous page.
getAndAdd(long) - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
getAndAdd(long) - Method in class com.hazelcast.client.impl.proxy.ClientPNCounterProxy
 
getAndAdd(long) - Method in interface com.hazelcast.cp.IAtomicLong
Atomically adds the given value to the current value.
getAndAdd(long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLong
 
getAndAdd(long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
getAndAdd(long) - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Adds the given value to the current value.
getAndAdd(long, VectorClock) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterImpl
Adds the given value to the current value.
getAndAdd(long) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterProxy
 
getAndAdd(long) - Method in class com.hazelcast.internal.jmx.AtomicLongMBean
 
getAndAdd(long) - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
getAndAdd(long) - Method in class com.hazelcast.internal.longregister.LongRegister
 
getAndAdd(long) - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
getAndAddAsync(long) - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
getAndAddAsync(long) - Method in interface com.hazelcast.cp.IAtomicLong
Atomically adds the given value to the current value.
getAndAddAsync(long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
getAndAddAsync(long) - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
getAndAddAsync(long) - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
GetAndAddMessageTask - Class in com.hazelcast.cp.internal.datastructures.atomiclong.client
Client message task for GetAndAddOp
GetAndAddMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetAndAddMessageTask
 
GetAndAddOp - Class in com.hazelcast.cp.internal.datastructures.atomiclong.operation
Operation for IAtomicLong.getAndAdd(long) (long, long)} and IAtomicLong.get()
GetAndAddOp() - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.operation.GetAndAddOp
 
GetAndAddOp(String, long) - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.operation.GetAndAddOp
 
GetAndAddOperation - Class in com.hazelcast.internal.longregister.operations
 
GetAndAddOperation() - Constructor for class com.hazelcast.internal.longregister.operations.GetAndAddOperation
 
GetAndAddOperation(String, long) - Constructor for class com.hazelcast.internal.longregister.operations.GetAndAddOperation
 
getAndAdvance() - Method in interface com.hazelcast.map.impl.querycache.accumulator.CyclicBuffer
Returns next unread event from this buffer and advances head sequence of this buffer by one.
getAndAdvance() - Method in class com.hazelcast.map.impl.querycache.accumulator.DefaultCyclicBuffer
 
getAndAlter(IFunction<Long, Long>) - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
getAndAlter(IFunction<T, T>) - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
getAndAlter(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.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.cp.IAtomicReference
Alters the currently stored reference by applying a function on it on and gets the old value.
getAndAlter(IFunction<Long, Long>) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
getAndAlter(IFunction<T, T>) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
getAndAlter(IFunction<Long, Long>) - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
getAndAlter(IFunction<Long, Long>) - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
getAndAlterAsync(IFunction<Long, Long>) - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
getAndAlterAsync(IFunction<T, T>) - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
getAndAlterAsync(IFunction<Long, Long>) - Method in interface com.hazelcast.cp.IAtomicLong
Alters the currently stored value by applying a function on it on and gets the old value.
getAndAlterAsync(IFunction<E, E>) - Method in interface com.hazelcast.cp.IAtomicReference
Alters the currently stored reference by applying a function on it on and gets the old value.
getAndAlterAsync(IFunction<Long, Long>) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
getAndAlterAsync(IFunction<T, T>) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
getAndAlterAsync(IFunction<Long, Long>) - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
getAndAlterAsync(IFunction<Long, Long>) - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
getAndDecrement() - Method in class com.hazelcast.client.impl.proxy.ClientPNCounterProxy
 
getAndDecrement() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Decrements by one the current value.
getAndDecrement() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterProxy
 
getAndInc() - Method in class com.hazelcast.internal.util.MutableInteger
 
getAndIncrement() - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
getAndIncrement() - Method in class com.hazelcast.client.impl.proxy.ClientPNCounterProxy
 
getAndIncrement() - Method in interface com.hazelcast.cp.IAtomicLong
Atomically increments the current value by one.
getAndIncrement() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
getAndIncrement() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Increments by one the current value.
getAndIncrement() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterProxy
 
getAndIncrement() - Method in class com.hazelcast.internal.jmx.AtomicLongMBean
 
getAndIncrement() - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
getAndIncrement() - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
getAndIncrementAsync() - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
getAndIncrementAsync() - Method in interface com.hazelcast.cp.IAtomicLong
Atomically increments the current value by one.
getAndIncrementAsync() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
getAndIncrementAsync() - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
getAndIncrementAsync() - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
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, UUID, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
getAndPut(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
 
getAndPut(K, V, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.CacheProxy
 
getAndPut(Data, Object, ExpiryPolicy, UUID, 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
 
getAndPut(K, V, ExpiryPolicy) - 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.
getAndPutAsync(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
 
getAndPutAsync(K, V, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.CacheProxy
 
getAndPutAsync(K, V) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
getAndPutAsync(K, V, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
getAndRemove(Data, UUID, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
getAndRemove(Data, UUID, int, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
getAndRemove(K) - Method in class com.hazelcast.cache.impl.CacheProxy
 
getAndRemove(Data, UUID, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Atomically removes the entry for a key only if it is currently mapped to some value.
getAndRemove(K) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
getAndRemoveAsync(K) - Method in interface com.hazelcast.cache.ICache
Asynchronously removes the entry for a key and returns the previously assigned value or null if no value was assigned.
getAndRemoveAsync(K) - Method in class com.hazelcast.cache.impl.CacheProxy
 
getAndRemoveAsync(K) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
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, UUID, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
getAndReplace(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
 
getAndReplace(K, V, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.CacheProxy
 
getAndReplace(Data, Object, ExpiryPolicy, UUID, 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(K, V, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
getAndReplaceAsync(K, V) - Method in interface com.hazelcast.cache.ICache
Asynchronously replaces the assigned value of the given key by the specified value and returns the previously assigned value.
getAndReplaceAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Asynchronously replaces the assigned value of the given key by the specified value using a custom ExpiryPolicy and returns the previously assigned value.
getAndReplaceAsync(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
 
getAndReplaceAsync(K, V, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.CacheProxy
 
getAndReplaceAsync(K, V) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
getAndReplaceAsync(K, V, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
getAndSet(long) - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
getAndSet(T) - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
getAndSet(long) - Method in interface com.hazelcast.cp.IAtomicLong
Atomically sets the given value and returns the old value.
getAndSet(E) - Method in interface com.hazelcast.cp.IAtomicReference
Gets the old value and sets the new value.
getAndSet(long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLong
 
getAndSet(long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
getAndSet(T) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
getAndSet(long) - Method in class com.hazelcast.internal.jmx.AtomicLongMBean
 
getAndSet(long) - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
getAndSet(long) - Method in class com.hazelcast.internal.longregister.LongRegister
 
getAndSet(long) - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
getAndSet(T, long) - Method in class com.hazelcast.internal.util.ItemCounter
Set counter for item and return previous value
getAndSetAsync(long) - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
getAndSetAsync(T) - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
getAndSetAsync(long) - Method in interface com.hazelcast.cp.IAtomicLong
Atomically sets the given value and returns the old value.
getAndSetAsync(E) - Method in interface com.hazelcast.cp.IAtomicReference
Gets the value and sets the new value.
getAndSetAsync(long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
getAndSetAsync(T) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
getAndSetAsync(long) - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
getAndSetAsync(long) - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
GetAndSetMessageTask - Class in com.hazelcast.cp.internal.datastructures.atomiclong.client
Client message task for GetAndSetOp
GetAndSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetAndSetMessageTask
 
GetAndSetOp - Class in com.hazelcast.cp.internal.datastructures.atomiclong.operation
GetAndSetOp() - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.operation.GetAndSetOp
 
GetAndSetOp(String, long) - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.operation.GetAndSetOp
 
GetAndSetOperation - Class in com.hazelcast.internal.longregister.operations
 
GetAndSetOperation() - Constructor for class com.hazelcast.internal.longregister.operations.GetAndSetOperation
 
GetAndSetOperation(String, long) - Constructor for class com.hazelcast.internal.longregister.operations.GetAndSetOperation
 
getAndSubtract(long) - Method in class com.hazelcast.client.impl.proxy.ClientPNCounterProxy
 
getAndSubtract(long) - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Subtracts the given value from the current value.
getAndSubtract(long, VectorClock) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterImpl
Subtracts the given value from the current value.
getAndSubtract(long) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterProxy
 
getAppendedEntryOnLeaderElection() - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Returns the entry to be appended if the no-op entry append on leader election feature is enabled.
getAppendRequestBackoffTimeoutInMillis() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getAppendRequestMaxEntryCount() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getAppliedMembers() - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Returns the currently effective member list of the raft group this node belongs to.
getAppliedMembers() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
getArray(JsonObject, String) - Static method in class com.hazelcast.internal.util.JsonUtil
Returns a field in a Json object as an array.
getArray(JsonObject, String, JsonArray) - Static method in class com.hazelcast.internal.util.JsonUtil
Returns a field in a Json object as an array.
getArrayIndex() - Method in class com.hazelcast.query.impl.getters.JsonPathCursor
Returns array index if the current item is array and not "any".
getAsDataList() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Returns data in the queue.
getAsync(K) - Method in interface com.hazelcast.cache.ICache
Asynchronously retrieves the mapped value of the given key using a custom ExpiryPolicy.
getAsync(K, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Asynchronously gets an entry from cache using a custom ExpiryPolicy.
getAsync(K) - Method in class com.hazelcast.cache.impl.CacheProxy
 
getAsync(K, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.CacheProxy
 
getAsync(K) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
getAsync(K, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
getAsync() - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
getAsync() - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
getAsync(K) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
getAsync(K) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
getAsync() - Method in interface com.hazelcast.cp.IAtomicLong
Gets the current value.
getAsync() - Method in interface com.hazelcast.cp.IAtomicReference
Gets the current value.
getAsync() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
getAsync() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
getAsync(K) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
getAsync(K) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
getAsync(K) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
getAsync(K) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
getAsync(K) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
getAsync() - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
getAsync() - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
getAsync(K) - Method in interface com.hazelcast.map.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.CacheOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
 
getAsyncBackupCount() - Method in class com.hazelcast.cardinality.impl.operations.CardinalityEstimatorBackupAwareOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
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.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.CardinalityEstimatorConfig
Gets the number of synchronous backups.
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.cp.internal.operation.unsafe.UnsafeRaftReplicateOp
 
getAsyncBackupCount() - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
getAsyncBackupCount() - Method in interface com.hazelcast.internal.locksupport.LockStoreInfo
 
getAsyncBackupCount() - Method in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.internal.longregister.operations.LongRegisterBackupAwareOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.map.impl.MapContainer
 
getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.AddIndexOperation
 
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.EntryOffloadableSetUnlockOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EntryOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EvictOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.MapFlushOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.MergeOperation
 
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.operation.SetTtlOperation
 
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.AbstractMultiMapOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.ringbuffer.impl.operations.MergeOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.scheduledexecutor.impl.operations.AbstractBackupAwareSchedulerOperation
 
getAsyncBackupCount() - Method in interface com.hazelcast.spi.impl.operationservice.BackupAwareOperation
The asynchronous backup count.
getAsyncBackupCount() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
 
getAsyncBackupCount() - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionOperation
 
getAsyncExecutorMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getAsyncInternal(Object, ExpiryPolicy, BiConsumer<V, Throwable>) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
getAsyncInternal(Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
getAsyncInternal(Object) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
getAtomicLong(String) - Method in class com.hazelcast.client.cp.internal.CPSubsystemImpl
 
getAtomicLong(String) - Method in interface com.hazelcast.cp.CPSubsystem
Returns a proxy for an IAtomicLong instance created on CP Subsystem.
getAtomicLong(String) - Method in class com.hazelcast.cp.internal.CPSubsystemImpl
 
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.cp.internal.CPSubsystemImpl
 
getAtomicReference(String) - Method in interface com.hazelcast.cp.CPSubsystem
Returns a proxy for an IAtomicReference instance created on CP Subsystem.
getAtomicReference(String) - Method in class com.hazelcast.cp.internal.CPSubsystemImpl
 
getAtomicValue(CPGroupId, String) - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueService
 
getAttachedSessions(CPGroupId) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
getAttachedSessions(CPGroupId) - Method in interface com.hazelcast.cp.internal.session.SessionAwareService
Returns a collection of session ids that this service has attached some resources.
getAttribute(String) - Method in class com.hazelcast.cluster.impl.AbstractMember
 
getAttribute(String) - Method in class com.hazelcast.cluster.impl.MemberImpl
 
getAttribute(String) - Method in interface com.hazelcast.cluster.Member
Returns the value of the specified key for this member or null if value is undefined.
getAttribute(Node, String) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
getAttribute(Node, String, boolean) - Static method in class com.hazelcast.config.DomConfigHelper
 
getAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
getAttribute(String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getAttribute(String) - Method in class com.hazelcast.internal.jmx.HazelcastMBean
 
getAttribute(String) - Method in class com.hazelcast.internal.metrics.jmx.MetricsMBean
 
getAttribute() - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
getAttribute() - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
 
getAttribute() - Method in class com.hazelcast.query.impl.predicates.BoundedRangePredicate
 
getAttribute() - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
 
getAttribute() - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
 
getAttribute() - Method in interface com.hazelcast.query.impl.predicates.RangePredicate
 
getAttribute() - Method in interface com.hazelcast.query.PredicateBuilder
 
getAttribute(Node, String) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
getAttributeConfigs() - Method in class com.hazelcast.config.MapConfig
 
getAttributeNode(String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getAttributeNodeNS(String, String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getAttributeNS(String, String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getAttributePath() - Method in class com.hazelcast.query.impl.getters.JsonPathCursor
 
getAttributes() - Method in class com.hazelcast.cluster.impl.AbstractMember
 
getAttributes() - Method in interface com.hazelcast.cluster.Member
Returns configured attributes for this member.
This method might not be available on all native clients.
getAttributes() - Method in class com.hazelcast.config.IndexConfig
Gets index attributes.
getAttributes() - Method in class com.hazelcast.config.MemberAttributeConfig
 
getAttributes() - Method in class com.hazelcast.internal.cluster.impl.JoinRequest
 
getAttributes() - Method in class com.hazelcast.internal.cluster.MemberInfo
 
getAttributes() - Method in class com.hazelcast.internal.config.IndexConfigReadOnly
 
getAttributes() - Method in class com.hazelcast.internal.config.MemberAttributeConfigReadOnly
 
getAttributes() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getAttributes(String[]) - Method in class com.hazelcast.internal.jmx.HazelcastMBean
 
getAttributes(String[]) - Method in class com.hazelcast.internal.metrics.jmx.MetricsMBean
 
getAttributeType(Class) - Static method in class com.hazelcast.query.impl.getters.ReflectionHelper
 
getAttributeValue(String) - Method in interface com.hazelcast.query.impl.Extractable
 
getAttributeValue(String) - Method in class com.hazelcast.query.impl.QueryableEntry
 
getAuditlogService() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
getAuditlogService() - Method in interface com.hazelcast.instance.impl.NodeExtension
 
getAuditLogService() - Method in interface com.hazelcast.internal.nio.IOService
 
getAuditLogService() - Method in class com.hazelcast.internal.nio.NodeIOService
 
getAvailable() - Method in class com.hazelcast.internal.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.
getAverageHitLatency() - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
 
getAverageHitLatency() - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Returns the average hit latency.
getAverageHitLatency() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the average hit latency (in nanoseconds) for the index.
getAverageHitSelectivity() - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
 
getAverageHitSelectivity() - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Returns the average hit selectivity.
getAverageHitSelectivity() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the average selectivity of the hits served by the index.
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.
getAwsConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the current AwsConfig.
getAwsConfig() - Method in class com.hazelcast.config.JoinConfig
 
getAwsConfig() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the AwsConfig used by the discovery mechanism for this WAN publisher.
getAzureConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the current AzureConfig.
getAzureConfig() - Method in class com.hazelcast.config.JoinConfig
 
getAzureConfig() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the AzureConfig used by the discovery mechanism for this WAN publisher.
getBackupAcks() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.NormalResponse
Returns the number of backups that needs to acknowledge before the invocation completes.
getBackupCount() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
 
getBackupCount() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
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.CardinalityEstimatorConfig
Gets the number of synchronous backups.
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.cp.internal.datastructures.spi.AbstractCPMigrationAwareService
 
getBackupCount() - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueService
 
getBackupCount() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
getBackupCount() - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
getBackupCount() - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
getBackupCount() - Method in interface com.hazelcast.internal.locksupport.LockStoreInfo
 
getBackupCount() - Method in class com.hazelcast.map.impl.MapContainer
 
getBackupCount() - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
 
getBackupCount() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
 
getBackupCount() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
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 interface com.hazelcast.wan.impl.InternalWanReplicationEvent
Returns the backup count (sync and async) for this WAN event.
getBackupDir() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Base directory for hot backups.
getBackupDirectory() - Method in interface com.hazelcast.hotrestart.HotRestartService
Returns the hot restart backup directory.
getBackupDirectory() - Method in class com.hazelcast.internal.hotrestart.NoOpHotRestartService
 
getBackupDirectory() - Method in interface com.hazelcast.monitor.HotRestartState
 
getBackupDirectory() - Method in class com.hazelcast.monitor.impl.HotRestartStateImpl
 
getBackupEntryCount() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
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.EmptyLocalReplicatedMapStats
 
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.
getBackupHandler() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
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.
getBackupListeners() - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
getBackupMap() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Return the map containing queue items when this instance is a backup replica.
getBackupOp() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
 
getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
 
getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
 
getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
 
getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
 
getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
 
getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperation
 
getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
 
getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
 
getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
 
getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
 
getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
 
getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
 
getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheSetExpiryPolicyOperation
 
getBackupOperation() - Method in class com.hazelcast.cardinality.impl.operations.AggregateOperation
 
getBackupOperation() - Method in class com.hazelcast.cardinality.impl.operations.MergeOperation
 
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.CollectionMergeOperation
 
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.QueueMergeOperation
 
getBackupOperation() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveOperation
 
getBackupOperation() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitOperation
 
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.TxnCommitOperation
 
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.cp.internal.operation.unsafe.UnsafeRaftReplicateOp
 
getBackupOperation() - Method in class com.hazelcast.durableexecutor.impl.operations.DisposeResultOperation
 
getBackupOperation() - Method in class com.hazelcast.durableexecutor.impl.operations.PutResultOperation
 
getBackupOperation() - Method in class com.hazelcast.durableexecutor.impl.operations.TaskOperation
 
getBackupOperation() - Method in class com.hazelcast.internal.locksupport.operations.LockOperation
 
getBackupOperation() - Method in class com.hazelcast.internal.locksupport.operations.UnlockOperation
 
getBackupOperation() - Method in class com.hazelcast.internal.longregister.operations.AddAndGetOperation
 
getBackupOperation() - Method in class com.hazelcast.internal.longregister.operations.GetAndAddOperation
 
getBackupOperation() - Method in class com.hazelcast.internal.longregister.operations.GetAndSetOperation
 
getBackupOperation() - Method in class com.hazelcast.internal.longregister.operations.SetOperation
 
getBackupOperation() - Method in class com.hazelcast.map.impl.operation.AddIndexOperation
 
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.EntryOffloadableSetUnlockOperation
 
getBackupOperation() - Method in class com.hazelcast.map.impl.operation.EntryOperation
 
getBackupOperation() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
 
getBackupOperation() - Method in class com.hazelcast.map.impl.operation.EvictOperation
 
getBackupOperation() - Method in class com.hazelcast.map.impl.operation.MapFlushOperation
 
getBackupOperation() - Method in class com.hazelcast.map.impl.operation.MergeOperation
 
getBackupOperation() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
 
getBackupOperation() - Method in class com.hazelcast.map.impl.operation.MultipleEntryWithPredicateOperation
 
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.operation.SetTtlOperation
 
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.DeleteOperation
 
getBackupOperation() - Method in class com.hazelcast.multimap.impl.operations.MergeOperation
 
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 class com.hazelcast.ringbuffer.impl.operations.MergeOperation
 
getBackupOperation() - Method in class com.hazelcast.scheduledexecutor.impl.operations.CancelTaskOperation
 
getBackupOperation() - Method in class com.hazelcast.scheduledexecutor.impl.operations.DisposeTaskOperation
 
getBackupOperation() - Method in class com.hazelcast.scheduledexecutor.impl.operations.MergeOperation
 
getBackupOperation() - Method in class com.hazelcast.scheduledexecutor.impl.operations.ScheduleTaskOperation
 
getBackupOperation() - Method in class com.hazelcast.scheduledexecutor.impl.operations.SyncStateOperation
 
getBackupOperation() - Method in interface com.hazelcast.spi.impl.operationservice.BackupAwareOperation
Creates the BackupOperation responsible for making the backup.
getBackupOperation() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
 
getBackupOperation() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
 
getBackupOperation() - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionOperation
 
getBackupProcessor() - Method in interface com.hazelcast.map.EntryProcessor
Get the entry processor to be applied to backup entries.
getBackupTaskStatus() - Method in interface com.hazelcast.hotrestart.HotRestartService
Returns the local hot restart backup task status (not the cluster backup status).
getBackupTaskStatus() - Method in class com.hazelcast.internal.hotrestart.NoOpHotRestartService
 
getBackupTaskStatus() - Method in interface com.hazelcast.monitor.HotRestartState
Returns the local hot restart backup task status (not the cluster backup status).
getBackupTaskStatus() - Method in class com.hazelcast.monitor.impl.HotRestartStateImpl
 
getBaseDir() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the base directory for persisting CP data.
getBaseDir() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Base directory for all Hot Restart stores.
getBaseName(String) - Static method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
 
getBaseURI() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getBatch() - Method in class com.hazelcast.map.impl.iterator.AbstractCursor
 
getBatchCount() - Method in class com.hazelcast.monitor.impl.LocalFlakeIdGeneratorStatsImpl
 
getBatchCount() - Method in interface com.hazelcast.monitor.LocalFlakeIdGeneratorStats
The average batch size can be calculated by dividing LocalFlakeIdGeneratorStats.getIdCount() by getBatchCount().
getBatchEventData() - Method in class com.hazelcast.map.impl.querycache.event.BatchIMapEvent
 
getBatchMaxDelayMillis() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the maximum amount of time in milliseconds to wait before sending a batch of events to target cluster, if WanBatchReplicationPublisherConfig.getBatchSize() of events have not arrived within this duration.
getBatchPublisherConfigs() - Method in class com.hazelcast.config.WanReplicationConfig
Returns the list of WAN publisher configurations using the built-in batching WAN implementation for this WAN replication.
getBatchSize() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
getBatchSize() - Method in class com.hazelcast.config.MergePolicyConfig
Returns the batch size, which will be used to determine the number of entries to be sent in a merge operation.
getBatchSize() - Method in class com.hazelcast.config.QueryCacheConfig
After reaching this size, node sends buffered events to QueryCache.
getBatchSize() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the maximum batch size that can be sent to target cluster.
getBatchSize() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
 
getBatchSize(String) - Method in class com.hazelcast.spi.impl.merge.AbstractMergeRunnable
This batch size can only be used with SplitBrainMergePolicy, legacy merge policies don't support batch data sending.
getBeforeUpdate - Variable in class com.hazelcast.client.impl.protocol.codec.PNCounterAddCodec.RequestParameters
true if the operation should return the counter value before the addition, false if it should return the value after the addition
getBindAddress(EndpointQualifier) - Method in interface com.hazelcast.instance.AddressPicker
Returns a server socket listener address.
getBindAddress() - Method in interface com.hazelcast.spi.MemberAddressProvider
What address should Hazelcast bind to.
getBindAddress(EndpointQualifier) - Method in interface com.hazelcast.spi.MemberAddressProvider
 
getBindings() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
 
getBlacklist() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
getBlacklistedPrefixes() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Return currently configured blacklist prefixes.
getBlobAndReset() - Method in class com.hazelcast.internal.metrics.managementcenter.MetricsCompressor
 
getBoolean(String, boolean) - Method in class com.hazelcast.internal.json.JsonObject
Returns the boolean value of the member with the specified name in this object.
getBoolean(Object, long) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Returns the boolean value at the supplied offset from the supplied object's base address.
getBoolean(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getBoolean(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getBoolean(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getBoolean(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getBoolean(long) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Reads the boolean value from given address.
getBoolean(JsonObject, String) - Static method in class com.hazelcast.internal.util.JsonUtil
Returns a field in a Json object as a boolean.
getBoolean(JsonObject, String, boolean) - Static method in class com.hazelcast.internal.util.JsonUtil
Returns a field in a Json object as a boolean.
getBoolean(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured boolean value of a HazelcastProperty.
getBooleanValue(String) - Static method in class com.hazelcast.config.DomConfigHelper
 
getBooleanVolatile(Object, long) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Reads the boolean value as volatile from given object by its offset.
getBooleanVolatile(long) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Reads the boolean value as volatile from given object by its offset.
getBooleanVolatile(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getBooleanVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getBooleanVolatile(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getBooleanVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
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 option value
getBufferSize() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
getBufferSize() - Method in class com.hazelcast.config.QueryCacheConfig
Returns the maximum number of events which can be stored in a buffer of partition.
getBufferSize() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
 
getBuild() - Method in class com.hazelcast.instance.BuildInfo
 
getBuild() - Method in class com.hazelcast.instance.JetBuildInfo
 
getBuild() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getBuildInfo() - Static method in class com.hazelcast.instance.BuildInfoProvider
Parses hazelcast-runtime.properties for BuildInfo; also checks for overrides in System.properties.
getBuildInfo() - Method in class com.hazelcast.instance.impl.Node
 
getBuildNumber() - Method in class com.hazelcast.instance.BuildInfo
 
getBuildNumber() - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
 
getBuiltinDefinitions() - Method in class com.hazelcast.internal.partition.impl.PartitionPortableHook
 
getBuiltinDefinitions() - Method in interface com.hazelcast.internal.serialization.PortableHook
 
getBuiltinDefinitions() - Method in class com.hazelcast.map.impl.client.MapPortableHook
 
getBuiltinDefinitions() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
 
getBuiltinDefinitions() - Method in class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
 
getBuiltinDefinitions() - Method in class com.hazelcast.spi.impl.SpiPortableHook
 
getBulkLoad() - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
 
getById(int) - Static method in enum com.hazelcast.client.impl.protocol.AuthenticationStatus
 
getById(int) - Static method in enum com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
 
getById(byte) - Static method in enum com.hazelcast.config.ConsistencyCheckStrategy
Returns the ConsistencyCheckStrategy for the given ID.
getById(int) - Static method in enum com.hazelcast.config.IndexType
Returns the IndexType as an enum.
getById(int) - Static method in enum com.hazelcast.config.MetadataPolicy
Returns the MetadataPolicy for the given ID.
getById(int) - Static method in enum com.hazelcast.config.WanAcknowledgeType
Returns the WanAcknowledgeType for the given ID.
getById(byte) - Static method in enum com.hazelcast.internal.util.IterationType
Returns the IterationType for the given ID.
getById(int) - Static method in enum com.hazelcast.ringbuffer.OverflowPolicy
Returns the OverflowPolicy for the given ID.
getById(int) - Static method in enum com.hazelcast.scheduledexecutor.impl.TaskDefinition.Type
 
getById(int) - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
 
getByStatus(int) - Static method in enum com.hazelcast.wan.impl.WanSyncStatus
 
getByte(R, long) - Method in interface com.hazelcast.internal.memory.ByteAccessStrategy
Return byte from external resource
getByte(Object, long) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Returns the byte value at the supplied offset from the supplied object's base address.
getByte(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getByte(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getByte(byte[], long) - Method in class com.hazelcast.internal.memory.impl.ByteArrayAccessStrategy
 
getByte(ByteBuffer, long) - Method in class com.hazelcast.internal.memory.impl.ByteBufferAccessStrategy
 
getByte(MemoryAccessor, long) - Method in class com.hazelcast.internal.memory.impl.CustomByteAccessStrategy
 
getByte(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getByte(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getByte(long) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Reads the byte value from given address.
getByteArray(String, String) - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
getByteArray(String, String) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
getByteOrder() - Method in class com.hazelcast.config.SerializationConfig
Note that result of useNativeByteOrder is not reflected to return value of this method.
getByteOrder() - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
getByteOrder() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
getByteOrder() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
getByteOrder() - Method in interface com.hazelcast.internal.serialization.InputOutputFactory
 
getByteOrder() - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
Returns the byte order used when serializing/deserializing objects.
getByteOrder() - Method in interface com.hazelcast.internal.serialization.PortableContext
 
getByteOrder() - Method in interface com.hazelcast.nio.ObjectDataInput
 
getByteOrder() - Method in interface com.hazelcast.nio.ObjectDataOutput
 
getBytes() - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
 
getBytes() - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
getBytesReceived() - Method in interface com.hazelcast.internal.networking.NetworkStats
Returns number of bytes received over all connections (active and closed) managed by the EndpointManager.
getBytesSent() - Method in interface com.hazelcast.internal.networking.NetworkStats
Returns number of bytes sent over all connections (active and closed) managed by the EndpointManager.
getByteVolatile(Object, long) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Reads the byte value as volatile from given object by its offset.
getByteVolatile(long) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Reads the byte value as volatile from given object by its offset.
getByteVolatile(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getByteVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getByteVolatile(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getByteVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getByType(int) - Static method in enum com.hazelcast.cache.CacheEventType
 
getByType(byte) - Static method in enum com.hazelcast.config.WanPublisherState
Returns the WanPublisherState as an enum.
getByType(int) - Static method in enum com.hazelcast.config.WanQueueFullBehavior
Returns the WANQueueFullBehavior as an enum.
getByType(int) - Static method in enum com.hazelcast.core.EntryEventType
 
getByType(int) - Static method in enum com.hazelcast.core.ItemEventType
 
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.HazelcastInstanceCacheManager
 
getCache(String) - Method in class com.hazelcast.client.impl.clientside.ClientICacheManager
 
getCache(String) - Method in interface com.hazelcast.core.ICacheManager
Returns the cache instance with the specified prefixed cache name.
getCache(String) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
 
getCacheByFullName(String) - Method in class com.hazelcast.cache.impl.HazelcastInstanceCacheManager
 
getCacheByFullName(String) - Method in class com.hazelcast.client.impl.clientside.ClientICacheManager
 
getCacheConfig(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
getCacheConfig(String, String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
getCacheConfig(String, String) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
 
getCacheConfig(String) - Method in interface com.hazelcast.cache.impl.ICacheService
 
getCacheConfig(String, String) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
 
getCacheConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getCacheConfig(String) - Method in class com.hazelcast.config.Config
Returns the CacheSimpleConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getCacheConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
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.client.impl.clientside.ClientDynamicClusterConfig
 
getCacheConfigs() - Method in class com.hazelcast.config.Config
Returns the map of cache configurations, mapped by config name.
getCacheConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getCacheContext(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
getCacheDeserializedValues() - Method in class com.hazelcast.config.MapConfig
Get current value cache settings
getCachedValue(Record) - Static method in class com.hazelcast.map.impl.record.Records
Get current cached value from the record.
getCachedValueUnsafe() - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
getCachedValueUnsafe() - Method in interface com.hazelcast.map.impl.record.Record
Get current cache value or null.
getCacheEntryEventFilterFactory() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
getCacheEntryListener() - Method in interface com.hazelcast.cache.impl.CacheEntryListenerProvider
Gets wrapped CacheEntryListener
getCacheEntryListener() - Method in class com.hazelcast.cache.impl.CacheEventListenerAdaptor
 
getCacheEntryListenerConfigurations() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getCacheEntryListenerConfigurations() - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
getCacheEntryListenerCount() - Method in class com.hazelcast.cache.impl.CacheContext
 
getCacheEntryListenerFactory() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
getCacheEntryListeners() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets a list of CacheSimpleEntryListenerConfig from this ICache.
getCacheEntryListeners() - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
GetCacheEntryRequest - Class in com.hazelcast.internal.management.request
Request for fetching cache entries.
GetCacheEntryRequest() - Constructor for class com.hazelcast.internal.management.request.GetCacheEntryRequest
 
GetCacheEntryRequest(String, String, String) - Constructor for class com.hazelcast.internal.management.request.GetCacheEntryRequest
 
GetCacheEntryRequest.CacheBrowserEntryView - Class in com.hazelcast.internal.management.request
 
GetCacheEntryRequest.GetCacheEntryViewEntryProcessor - Class in com.hazelcast.internal.management.request
 
GetCacheEntryViewEntryProcessor() - Constructor for class com.hazelcast.internal.management.request.GetCacheEntryRequest.GetCacheEntryViewEntryProcessor
 
getCacheEventHandler() - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
getCacheEventType() - Method in interface com.hazelcast.cache.impl.CacheEventData
Gets cache event type of this event data.
getCacheEventType() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
 
getCacheEvictions() - Method in interface com.hazelcast.cache.CacheStatistics
The total number of evictions from the cache.
getCacheEvictions() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
getCacheEvictions() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
 
getCacheEvictions() - Method in class com.hazelcast.client.cache.impl.ClientCacheStatisticsImpl
 
getCacheEvictions() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
 
getCacheEvictions() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the number of evictions on the cache.
getCacheExpiries() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
The total number of expiries from the cache.
getCacheExpiries() - Method in class com.hazelcast.client.cache.impl.ClientCacheStatisticsImpl
 
getCacheGets() - Method in interface com.hazelcast.cache.CacheStatistics
The total number of requests to the cache.
getCacheGets() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
getCacheGets() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
 
getCacheGets() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
 
getCacheGets() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the number of gets on the cache.
getCacheGetTimeTakenNanos() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
getCacheHitPercentage() - Method in interface com.hazelcast.cache.CacheStatistics
This is a measure of cache efficiency.
getCacheHitPercentage() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
getCacheHitPercentage() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
 
getCacheHitPercentage() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
 
getCacheHitPercentage() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the percentage of hits (successful get operations) on the cache.
getCacheHits() - Method in interface com.hazelcast.cache.CacheStatistics
The number of get requests that were satisfied by the cache.
getCacheHits() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
getCacheHits() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
 
getCacheHits() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
 
getCacheHits() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the number of hits (successful get operations) on the cache.
getCacheId() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
 
getCacheId() - Method in interface com.hazelcast.map.impl.querycache.subscriber.InternalQueryCache
 
getCacheId() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
getCacheLoader() - Method in class com.hazelcast.config.CacheSimpleConfig
Get classname of a class to be used as CacheLoader.
getCacheLoaderFactory() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
getCacheLoaderFactory() - Method in class com.hazelcast.config.AbstractCacheConfig
 
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.client.impl.clientside.HazelcastClientInstanceImpl
 
getCacheManager() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getCacheManager() - Method in interface com.hazelcast.core.HazelcastInstance
Obtain the ICacheManager that provides access to JSR-107 (JCache) caches configured on a Hazelcast cluster.
getCacheManager() - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getCacheManager() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getCacheManager(HazelcastInstance, String, Properties) - Static method in class com.hazelcast.spring.cache.SpringHazelcastCachingProvider
Creates a CacheManager on an existing HazelcastInstance.
getCacheManager(String, Properties) - Static method in class com.hazelcast.spring.cache.SpringHazelcastCachingProvider
 
getCacheMisses() - Method in interface com.hazelcast.cache.CacheStatistics
A miss is a get request that is not satisfied.
getCacheMisses() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
getCacheMisses() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
 
getCacheMisses() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
 
getCacheMisses() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the number of missed cache accesses on the cache.
getCacheMissPercentage() - Method in interface com.hazelcast.cache.CacheStatistics
Returns the percentage of cache accesses that did not find a requested entry in the cache.
getCacheMissPercentage() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
getCacheMissPercentage() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
 
getCacheMissPercentage() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
 
getCacheMissPercentage() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the percentage of missed cache accesses on the cache.
getCacheName() - Method in class com.hazelcast.cache.impl.CacheEventContext
 
getCacheName() - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRequest
 
getCacheNames() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
getCacheNames() - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
 
getCacheNameWithPrefix(String) - Method in interface com.hazelcast.cache.HazelcastCacheManager
Gets the cache name by adding the manager prefix.
getCacheNameWithPrefix(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
getCacheOperationProvider(String, InMemoryFormat) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
getCacheOperationProvider(String, InMemoryFormat) - Method in interface com.hazelcast.cache.impl.ICacheService
Creates cache operations according to the storage-type of the cache
getCachePartitionLostListenerConfigs() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
getCachePuts() - Method in interface com.hazelcast.cache.CacheStatistics
The total number of puts to the cache.
getCachePuts() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
getCachePuts() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
 
getCachePuts() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
 
getCachePuts() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the number of puts to the queue.
getCachePutTimeTakenNanos() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
getCacheRemovals() - Method in interface com.hazelcast.cache.CacheStatistics
The total number of removals from the cache.
getCacheRemovals() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
getCacheRemovals() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
 
getCacheRemovals() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
 
getCacheRemovals() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the number of removals from the queue.
getCacheRemoveTimeTakenNanos() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
getCacheService() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
 
getCacheService() - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
 
getCacheSimpleConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
getCacheSimpleConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Returns all registered cache configurations.
getCacheStats() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
getCacheStats() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Gets the Cache statistics associated with this CacheService.
getCacheTimeTakenNanos - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
getCacheWanEventPublisher() - Method in class com.hazelcast.cache.impl.CacheService
 
getCacheWanEventPublisher() - Method in interface com.hazelcast.cache.impl.ICacheService
Returns the WAN event publisher responsible for publishing primary and backup WAN events for caches.
getCacheWriter() - Method in class com.hazelcast.config.CacheSimpleConfig
Get classname of a class to be used as CacheWriter.
getCacheWriterFactory() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
getCacheWriterFactory() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getCacheWriterFactory() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the factory for the CacheWriter.
getCachingProvider() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
getCaller() - Method in class com.hazelcast.collection.impl.collection.CollectionEvent
 
getCaller() - Method in interface com.hazelcast.map.impl.event.EventData
 
getCaller() - Method in class com.hazelcast.map.impl.querycache.event.BatchEventData
 
getCaller() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
getCaller() - Method in class com.hazelcast.map.impl.querycache.event.LocalCacheWideEventData
 
getCaller() - Method in class com.hazelcast.map.impl.querycache.event.LocalEntryEventData
 
getCallerAddress() - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
getCallerProvenance() - Method in class com.hazelcast.map.impl.operation.MapOperation
 
getCallerUuid() - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
getCallerUuid() - Method in class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
 
getCallId() - Method in class com.hazelcast.client.impl.spi.impl.listener.ClientEventRegistration
Call ID of first event registration request
getCallId() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
Returns the call ID of the operation this response belongs to.
getCallId() - Method in class com.hazelcast.spi.impl.operationservice.Operation
Gets the call ID of this operation.
getCallTimeout() - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
 
getCallTimeout() - Method in class com.hazelcast.spi.impl.operationservice.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.
getCapacity() - Method in class com.hazelcast.config.DurableExecutorConfig
Gets the ring buffer capacity of the executor task.
getCapacity() - Method in class com.hazelcast.config.EventJournalConfig
Gets the capacity of the event journal.
getCapacity() - Method in class com.hazelcast.config.RingbufferConfig
Gets the capacity of the ringbuffer.
getCapacity() - Method in class com.hazelcast.config.ScheduledExecutorConfig
Gets the capacity of the executor
getCapacity() - Method in class com.hazelcast.internal.metrics.managementcenter.ConcurrentArrayRingbuffer
 
getCapacity() - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
 
getCapacity() - Method in interface com.hazelcast.ringbuffer.impl.Ringbuffer
Returns the capacity of this ringbuffer.
getCapacity() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
Returns the capacity of this ringbuffer.
getCapacity() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Returns the capacity of this ringbuffer.
getCardinalityEstimator(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getCardinalityEstimator(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getCardinalityEstimator(String) - Method in interface com.hazelcast.core.HazelcastInstance
Obtain a CardinalityEstimator with the given name.
getCardinalityEstimator(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getCardinalityEstimator(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getCardinalityEstimatorConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getCardinalityEstimatorConfig(String) - Method in class com.hazelcast.config.Config
Returns the CardinalityEstimatorConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getCardinalityEstimatorConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getCardinalityEstimatorConfigs() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getCardinalityEstimatorConfigs() - Method in class com.hazelcast.config.Config
Returns the map of cardinality estimator configurations, mapped by config name.
getCardinalityEstimatorConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
getCardinalityEstimatorConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Returns all registered cardinality estimator configurations.
getCardinalityEstimatorConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getCardinalityEstimatorContainer(String) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorService
 
getCardinalityEstimatorContainer() - Method in class com.hazelcast.cardinality.impl.operations.AbstractCardinalityEstimatorOperation
 
getCause() - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture.ExceptionalResult
 
getCause() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.ErrorResponse
 
getChannel() - Method in class com.hazelcast.internal.networking.nio.NioPipeline
 
getChannel() - Method in class com.hazelcast.internal.networking.ServerSocketRegistry.Pair
 
getChannel() - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
getChannelInitializerProvider() - Method in class com.hazelcast.client.impl.clientside.CandidateClusterContext
 
getChannels() - Method in class com.hazelcast.internal.networking.nio.NioNetworking
 
getChar(Object, long) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Returns the char value at the supplied offset from the supplied object's base address.
getChar(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getChar(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getChar(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getChar(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getChar(long) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Reads the char value from given address.
getCharVolatile(Object, long) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Reads the char value as volatile from given object by its offset.
getCharVolatile(long) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Reads the char value as volatile from given object by its offset.
getCharVolatile(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getCharVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getCharVolatile(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getCharVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getChild(int) - Method in class com.hazelcast.json.internal.JsonSchemaStructNode
Returns a name-value pair for the ith child of this struct.
getChildCount() - Method in class com.hazelcast.json.internal.JsonSchemaStructNode
The size of this object in terms of items or attributes it contains.
getChildNodes() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getClassCacheMode() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Return the current ClassCacheMode
getClassDataOrNull(String) - Method in class com.hazelcast.internal.usercodedeployment.impl.ClassDataProvider
 
getClassDataOrNull(String) - Method in class com.hazelcast.internal.usercodedeployment.UserCodeDeploymentService
 
getClassDefinitionList() - Method in class com.hazelcast.client.impl.spi.impl.ClientUserCodeDeploymentService
 
getClassDefinitions() - Method in class com.hazelcast.config.SerializationConfig
 
getClasses() - Method in class com.hazelcast.config.ClassFilter
Returns unmodifiable set of class names.
getClassId() - Method in class com.hazelcast.aggregation.impl.BigDecimalAverageAggregator
 
getClassId() - Method in class com.hazelcast.aggregation.impl.BigDecimalSumAggregator
 
getClassId() - Method in class com.hazelcast.aggregation.impl.BigIntegerAverageAggregator
 
getClassId() - Method in class com.hazelcast.aggregation.impl.BigIntegerSumAggregator
 
getClassId() - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
getClassId() - Method in class com.hazelcast.aggregation.impl.CountAggregator
 
getClassId() - Method in class com.hazelcast.aggregation.impl.DistinctValuesAggregator
 
getClassId() - Method in class com.hazelcast.aggregation.impl.DoubleAverageAggregator
 
getClassId() - Method in class com.hazelcast.aggregation.impl.DoubleSumAggregator
 
getClassId() - Method in class com.hazelcast.aggregation.impl.FixedSumAggregator
 
getClassId() - Method in class com.hazelcast.aggregation.impl.FloatingPointSumAggregator
 
getClassId() - Method in class com.hazelcast.aggregation.impl.IntegerAverageAggregator
 
getClassId() - Method in class com.hazelcast.aggregation.impl.IntegerSumAggregator
 
getClassId() - Method in class com.hazelcast.aggregation.impl.LongAverageAggregator
 
getClassId() - Method in class com.hazelcast.aggregation.impl.LongSumAggregator
 
getClassId() - Method in class com.hazelcast.aggregation.impl.MaxAggregator
 
getClassId() - Method in class com.hazelcast.aggregation.impl.MaxByAggregator
 
getClassId() - Method in class com.hazelcast.aggregation.impl.MinAggregator
 
getClassId() - Method in class com.hazelcast.aggregation.impl.MinByAggregator
 
getClassId() - Method in class com.hazelcast.aggregation.impl.NumberAverageAggregator
 
getClassId() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
getClassId() - Method in class com.hazelcast.cache.impl.CacheClearResponse
 
getClassId() - Method in class com.hazelcast.cache.impl.CacheEntryIterationResult
 
getClassId() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
 
getClassId() - Method in class com.hazelcast.cache.impl.CacheEventListenerAdaptor
 
getClassId() - Method in class com.hazelcast.cache.impl.CacheEventSet
 
getClassId() - Method in class com.hazelcast.cache.impl.CacheKeyIterationResult
 
getClassId() - Method in class com.hazelcast.cache.impl.CachePartitionEventData
 
getClassId() - Method in class com.hazelcast.cache.impl.event.CachePartitionLostEventFilter
 
getClassId() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalReadOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalReadResultSetImpl
 
getClassId() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalSubscribeOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.journal.DeserializingEventJournalCacheEvent
 
getClassId() - Method in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
 
getClassId() - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.AddCacheConfigOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheContainsKeyOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
Deprecated.
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheDestroyOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheEntryIteratorOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheExpireBatchBackupOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation.MetaDataResponse
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheGetOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheKeyIteratorOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperationFactory
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheNearCacheStateHolder
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CachePutBackupOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheSetExpiryPolicyBackupOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheSetExpiryPolicyOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
 
getClassId() - Method in class com.hazelcast.cache.impl.operation.OnJoinCacheOperation
 
getClassId() - Method in class com.hazelcast.cache.impl.PreJoinCacheConfig
 
getClassId() - Method in class com.hazelcast.cache.impl.record.CacheDataRecord
 
getClassId() - Method in class com.hazelcast.cache.impl.record.CacheObjectRecord
 
getClassId() - Method in class com.hazelcast.cache.impl.tenantcontrol.CacheDestroyEventContext
 
getClassId() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
 
getClassId() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.DenseHyperLogLogEncoder
 
getClassId() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogImpl
 
getClassId() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.SparseHyperLogLogEncoder
 
getClassId() - Method in class com.hazelcast.cardinality.impl.operations.AggregateBackupOperation
 
getClassId() - Method in class com.hazelcast.cardinality.impl.operations.AggregateOperation
 
getClassId() - Method in class com.hazelcast.cardinality.impl.operations.EstimateOperation
 
getClassId() - Method in class com.hazelcast.cardinality.impl.operations.MergeBackupOperation
 
getClassId() - Method in class com.hazelcast.cardinality.impl.operations.MergeOperation
 
getClassId() - Method in class com.hazelcast.cardinality.impl.operations.ReplicationOperation
 
getClassId() - Method in class com.hazelcast.client.impl.operations.GetConnectedClientsOperation
 
getClassId() - Method in class com.hazelcast.client.impl.operations.OperationFactoryWrapper
 
getClassId() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsOperation
 
getClassId() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsOperationFactory
 
getClassId() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsOperation
 
getClassId() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsOperationFactory
 
getClassId() - Method in class com.hazelcast.cluster.Address
 
getClassId() - Method in class com.hazelcast.cluster.impl.MemberImpl
 
getClassId() - Method in class com.hazelcast.cluster.impl.VectorClock
 
getClassId() - Method in class com.hazelcast.collection.impl.collection.CollectionEvent
 
getClassId() - Method in class com.hazelcast.collection.impl.collection.CollectionEventFilter
 
getClassId() - Method in class com.hazelcast.collection.impl.collection.CollectionItem
 
getClassId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionClearBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionClearOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionCompareAndRemoveOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionContainsOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionGetAllOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionIsEmptyOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionMergeBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionMergeOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionSizeOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.collection.TxCollectionItem
 
getClassId() - Method in class com.hazelcast.collection.impl.list.ListContainer
 
getClassId() - Method in class com.hazelcast.collection.impl.list.operations.ListAddAllOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.list.operations.ListAddOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.list.operations.ListGetOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.list.operations.ListIndexOfOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.list.operations.ListRemoveOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.list.operations.ListReplicationOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.list.operations.ListSetBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.list.operations.ListSetOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.list.operations.ListSubOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.AddAllBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.AddAllOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.CheckAndEvictOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.ClearBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.ClearOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.ContainsOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.DrainBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.DrainOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.IsEmptyOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.IteratorOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.OfferBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.PeekOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.PollBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.QueueMergeBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.QueueMergeOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.QueueReplicationOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.RemainingCapacityOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.operations.SizeOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.QueueEvent
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.QueueEventFilter
 
getClassId() - Method in class com.hazelcast.collection.impl.queue.QueueItem
 
getClassId() - Method in class com.hazelcast.collection.impl.set.operations.SetReplicationOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.set.SetContainer
 
getClassId() - Method in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
 
getClassId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveAddOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveRemoveOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTransactionRollbackOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.QueueTransactionRollbackOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPeekOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackBackupOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackOperation
 
getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.QueueTransactionLogRecord
 
getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.TxQueueItem
 
getClassId() - Method in class com.hazelcast.config.AttributeConfig
 
getClassId() - Method in class com.hazelcast.config.AwsConfig
 
getClassId() - Method in class com.hazelcast.config.AzureConfig
 
getClassId() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
 
getClassId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
getClassId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
getClassId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
getClassId() - Method in class com.hazelcast.config.CacheSimpleConfig
 
getClassId() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
getClassId() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
getClassId() - Method in class com.hazelcast.config.CustomWanPublisherConfig
 
getClassId() - Method in class com.hazelcast.config.DiscoveryConfig
 
getClassId() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
getClassId() - Method in class com.hazelcast.config.DurableExecutorConfig
 
getClassId() - Method in class com.hazelcast.config.EntryListenerConfig
 
getClassId() - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
getClassId() - Method in class com.hazelcast.config.EurekaConfig
 
getClassId() - Method in class com.hazelcast.config.EventJournalConfig
 
getClassId() - Method in class com.hazelcast.config.ExecutorConfig
 
getClassId() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getClassId() - Method in class com.hazelcast.config.GcpConfig
 
getClassId() - Method in class com.hazelcast.config.HotRestartConfig
 
getClassId() - Method in class com.hazelcast.config.IndexConfig
 
getClassId() - Method in class com.hazelcast.config.ItemListenerConfig
 
getClassId() - Method in class com.hazelcast.config.KubernetesConfig
 
getClassId() - Method in class com.hazelcast.config.ListConfig
 
getClassId() - Method in class com.hazelcast.config.ListenerConfig
 
getClassId() - Method in class com.hazelcast.config.MapConfig
 
getClassId() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
 
getClassId() - Method in class com.hazelcast.config.MapStoreConfig
 
getClassId() - Method in class com.hazelcast.config.MergePolicyConfig
 
getClassId() - Method in class com.hazelcast.config.MerkleTreeConfig
 
getClassId() - Method in class com.hazelcast.config.MultiMapConfig
 
getClassId() - Method in class com.hazelcast.config.NearCacheConfig
 
getClassId() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
getClassId() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
getClassId() - Method in class com.hazelcast.config.PNCounterConfig
 
getClassId() - Method in class com.hazelcast.config.PredicateConfig
 
getClassId() - Method in class com.hazelcast.config.QueryCacheConfig
 
getClassId() - Method in class com.hazelcast.config.QueueConfig
 
getClassId() - Method in class com.hazelcast.config.QueueStoreConfig
 
getClassId() - Method in class com.hazelcast.config.ReliableTopicConfig
 
getClassId() - Method in class com.hazelcast.config.ReplicatedMapConfig
 
getClassId() - Method in class com.hazelcast.config.RingbufferConfig
 
getClassId() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getClassId() - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
getClassId() - Method in class com.hazelcast.config.SetConfig
 
getClassId() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
getClassId() - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
 
getClassId() - Method in class com.hazelcast.config.TopicConfig
 
getClassId() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
getClassId() - Method in class com.hazelcast.config.WanConsumerConfig
 
getClassId() - Method in class com.hazelcast.config.WanReplicationConfig
 
getClassId() - Method in class com.hazelcast.config.WanSyncConfig
 
getClassId() - Method in class com.hazelcast.cp.internal.CPGroupInfo
 
getClassId() - Method in class com.hazelcast.cp.internal.CPGroupSummary
 
getClassId() - Method in class com.hazelcast.cp.internal.CPMemberInfo
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongSnapshot
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.AddAndGetOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.AlterOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.ApplyOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.CompareAndSetOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.GetAndAddOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.GetAndSetOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.LocalGetOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefSnapshot
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.ApplyOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.CompareAndSetOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.ContainsOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.GetOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.SetOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.AwaitInvocationKey
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatch
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchRegistry
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.AwaitOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.CountDownOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.GetCountOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.GetRoundOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.TrySetCountOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.lock.Lock
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockEndpoint
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockInvocationKey
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockOwnershipState
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.GetLockOwnershipStateOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.LockOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.TryLockOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.UnlockOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.AcquireInvocationKey
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.AcquirePermitsOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.AvailablePermitsOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.ChangePermitsOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.DrainPermitsOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.InitSemaphoreOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.ReleasePermitsOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.Semaphore
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreEndpoint
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreRegistry
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.operation.ExpireWaitKeysOp
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKeyContainer
 
getClassId() - Method in class com.hazelcast.cp.internal.datastructures.spi.operation.DestroyRaftObjectOp
 
getClassId() - Method in class com.hazelcast.cp.internal.MembershipChangeSchedule.CPGroupMembershipChange
 
getClassId() - Method in class com.hazelcast.cp.internal.MembershipChangeSchedule
 
getClassId() - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.ChangeRaftGroupMembershipOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.DefaultRaftReplicateOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.DestroyRaftGroupOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.GetLeadedGroupsOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.integration.AppendFailureResponseOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.integration.AppendRequestOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.integration.AppendSuccessResponseOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.integration.InstallSnapshotOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.integration.PreVoteRequestOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.integration.PreVoteResponseOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.integration.TriggerLeaderElectionOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.integration.VoteRequestOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.integration.VoteResponseOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.RaftQueryOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.RestartCPMemberOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.TransferLeadershipOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.unsafe.UnsafeRaftBackupOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.unsafe.UnsafeRaftQueryOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.unsafe.UnsafeRaftReplicateOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.unsafe.UnsafeSnapshotReplicationOp
 
getClassId() - Method in class com.hazelcast.cp.internal.operation.unsafe.UnsafeStateReplicationOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raft.command.DestroyRaftGroupCmd
 
getClassId() - Method in class com.hazelcast.cp.internal.raft.impl.command.UpdateRaftGroupMembersCmd
 
getClassId() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendFailureResponse
 
getClassId() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendRequest
 
getClassId() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendSuccessResponse
 
getClassId() - Method in class com.hazelcast.cp.internal.raft.impl.dto.InstallSnapshot
 
getClassId() - Method in class com.hazelcast.cp.internal.raft.impl.dto.PreVoteRequest
 
getClassId() - Method in class com.hazelcast.cp.internal.raft.impl.dto.PreVoteResponse
 
getClassId() - Method in class com.hazelcast.cp.internal.raft.impl.dto.TriggerLeaderElection
 
getClassId() - Method in class com.hazelcast.cp.internal.raft.impl.dto.VoteRequest
 
getClassId() - Method in class com.hazelcast.cp.internal.raft.impl.dto.VoteResponse
 
getClassId() - Method in class com.hazelcast.cp.internal.raft.impl.log.LogEntry
 
getClassId() - Method in class com.hazelcast.cp.internal.raft.impl.log.SnapshotEntry
 
getClassId() - Method in class com.hazelcast.cp.internal.RaftEndpointImpl
 
getClassId() - Method in class com.hazelcast.cp.internal.RaftGroupId
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.GetInitialRaftGroupMembersIfCurrentGroupMemberOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.metadata.AddCPMemberOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.metadata.CompleteDestroyRaftGroupsOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.metadata.CompleteRaftGroupMembershipChangesOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.metadata.CreateRaftGroupOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.metadata.CreateRaftNodeOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.metadata.DestroyRaftNodesOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.metadata.ForceDestroyRaftGroupOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetActiveCPMembersOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetActiveRaftGroupByNameOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetActiveRaftGroupIdsOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetDestroyingRaftGroupIdsOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetMembershipChangeScheduleOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetRaftGroupIdsOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetRaftGroupOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.metadata.InitMetadataRaftGroupOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.metadata.PublishActiveCPMembersOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.metadata.RaftServicePreJoinOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.metadata.RemoveCPMemberOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.metadata.TriggerDestroyRaftGroupOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.NotifyTermChangeOp
 
getClassId() - Method in class com.hazelcast.cp.internal.raftop.snapshot.RestoreSnapshotOp
 
getClassId() - Method in class com.hazelcast.cp.internal.session.CPSessionInfo
 
getClassId() - Method in class com.hazelcast.cp.internal.session.operation.CloseInactiveSessionsOp
 
getClassId() - Method in class com.hazelcast.cp.internal.session.operation.CloseSessionOp
 
getClassId() - Method in class com.hazelcast.cp.internal.session.operation.CreateSessionOp
 
getClassId() - Method in class com.hazelcast.cp.internal.session.operation.ExpireSessionsOp
 
getClassId() - Method in class com.hazelcast.cp.internal.session.operation.GenerateThreadIdOp
 
getClassId() - Method in class com.hazelcast.cp.internal.session.operation.GetSessionsOp
 
getClassId() - Method in class com.hazelcast.cp.internal.session.operation.HeartbeatSessionOp
 
getClassId() - Method in class com.hazelcast.cp.internal.session.SessionResponse
 
getClassId() - Method in class com.hazelcast.cp.internal.UnsafeModePartitionState
 
getClassId() - Method in class com.hazelcast.durableexecutor.impl.operations.DisposeResultBackupOperation
 
getClassId() - Method in class com.hazelcast.durableexecutor.impl.operations.DisposeResultOperation
 
getClassId() - Method in class com.hazelcast.durableexecutor.impl.operations.PutResultBackupOperation
 
getClassId() - Method in class com.hazelcast.durableexecutor.impl.operations.PutResultOperation
 
getClassId() - Method in class com.hazelcast.durableexecutor.impl.operations.ReplicationOperation
 
getClassId() - Method in class com.hazelcast.durableexecutor.impl.operations.RetrieveAndDisposeResultOperation
 
getClassId() - Method in class com.hazelcast.durableexecutor.impl.operations.RetrieveResultOperation
 
getClassId() - Method in class com.hazelcast.durableexecutor.impl.operations.ShutdownOperation
 
getClassId() - Method in class com.hazelcast.durableexecutor.impl.operations.TaskBackupOperation
 
getClassId() - Method in class com.hazelcast.durableexecutor.impl.operations.TaskOperation
 
getClassId() - Method in class com.hazelcast.executor.impl.operations.CallableTaskOperation
 
getClassId() - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
 
getClassId() - Method in class com.hazelcast.executor.impl.operations.MemberCallableTaskOperation
 
getClassId() - Method in class com.hazelcast.executor.impl.operations.ShutdownOperation
 
getClassId() - Method in class com.hazelcast.executor.impl.RunnableAdapter
 
getClassId() - Method in class com.hazelcast.instance.EndpointQualifier
 
getClassId() - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
 
getClassId() - Method in class com.hazelcast.internal.ascii.rest.RestValue
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.BindMessage
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateChange
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateTransactionLogRecord
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.ConfigCheck
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.ExtendedBindMessage
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.JoinRequest
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.MembersView
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.MembersViewMetadata
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.AuthenticationFailureOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.BeforeJoinCheckFailureOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.ClusterMismatchOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.CommitClusterStateOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.ConfigMismatchOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.ExplicitSuspicionOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.FetchMembersViewOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.FinalizeJoinOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.HeartbeatComplaintOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.HeartbeatOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.JoinMastershipClaimOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.JoinRequestOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.LockClusterStateOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.MasterResponseOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.MemberAttributeChangedOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.MembersUpdateOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.MergeClustersOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.OnJoinOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.PromoteLiteMemberOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.RollbackClusterStateOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.ShutdownNodeOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.SplitBrainMergeValidationOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.TriggerExplicitSuspicionOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.TriggerMemberListPublishOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.operations.WhoisMasterOp
 
getClassId() - Method in class com.hazelcast.internal.cluster.impl.SplitBrainJoinMessage
 
getClassId() - Method in class com.hazelcast.internal.cluster.MemberInfo
 
getClassId() - Method in class com.hazelcast.internal.config.NearCacheConfigReadOnly
 
getClassId() - Method in class com.hazelcast.internal.config.NearCachePreloaderConfigReadOnly
 
getClassId() - Method in class com.hazelcast.internal.crdt.pncounter.operations.AddOperation
 
getClassId() - Method in class com.hazelcast.internal.crdt.pncounter.operations.CRDTTimestampedLong
 
getClassId() - Method in class com.hazelcast.internal.crdt.pncounter.operations.GetOperation
 
getClassId() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterImpl
 
getClassId() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterReplicationOperation
 
getClassId() - Method in class com.hazelcast.internal.dynamicconfig.AddDynamicConfigOperation
 
getClassId() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigPreJoinOperation
 
getClassId() - Method in class com.hazelcast.internal.journal.DeserializingEntry
 
getClassId() - Method in class com.hazelcast.internal.journal.EventJournalInitialSubscriberState
 
getClassId() - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
getClassId() - Method in class com.hazelcast.internal.locksupport.operations.IsLockedOperation
 
getClassId() - Method in class com.hazelcast.internal.locksupport.operations.LocalLockCleanupOperation
 
getClassId() - Method in class com.hazelcast.internal.locksupport.operations.LockBackupOperation
 
getClassId() - Method in class com.hazelcast.internal.locksupport.operations.LockOperation
 
getClassId() - Method in class com.hazelcast.internal.locksupport.operations.LockReplicationOperation
 
getClassId() - Method in class com.hazelcast.internal.locksupport.operations.UnlockBackupOperation
 
getClassId() - Method in class com.hazelcast.internal.locksupport.operations.UnlockIfLeaseExpiredOperation
 
getClassId() - Method in class com.hazelcast.internal.locksupport.operations.UnlockOperation
 
getClassId() - Method in class com.hazelcast.internal.longregister.operations.AddAndGetOperation
 
getClassId() - Method in class com.hazelcast.internal.longregister.operations.AddBackupOperation
 
getClassId() - Method in class com.hazelcast.internal.longregister.operations.GetAndAddOperation
 
getClassId() - Method in class com.hazelcast.internal.longregister.operations.GetAndSetOperation
 
getClassId() - Method in class com.hazelcast.internal.longregister.operations.GetOperation
 
getClassId() - Method in class com.hazelcast.internal.longregister.operations.LongRegisterReplicationOperation
 
getClassId() - Method in class com.hazelcast.internal.longregister.operations.SetBackupOperation
 
getClassId() - Method in class com.hazelcast.internal.longregister.operations.SetOperation
 
getClassId() - Method in class com.hazelcast.internal.management.dto.MapConfigDTO
 
getClassId() - Method in class com.hazelcast.internal.management.dto.PermissionConfigDTO
 
getClassId() - Method in class com.hazelcast.internal.management.operation.ScriptExecutorOperation
 
getClassId() - Method in class com.hazelcast.internal.management.operation.SetLicenseOperation
 
getClassId() - Method in class com.hazelcast.internal.management.operation.UpdateManagementCenterUrlOperation
 
getClassId() - Method in class com.hazelcast.internal.management.operation.UpdateMapConfigOperation
 
getClassId() - Method in class com.hazelcast.internal.management.operation.UpdatePermissionConfigOperation
 
getClassId() - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.CacheBrowserEntryView
 
getClassId() - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.GetCacheEntryViewEntryProcessor
 
getClassId() - Method in class com.hazelcast.internal.metrics.managementcenter.ReadMetricsOperation
 
getClassId() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.BatchNearCacheInvalidation
 
getClassId() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.SingleNearCacheInvalidation
 
getClassId() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
getClassId() - Method in class com.hazelcast.internal.partition.MigrationStateImpl
 
getClassId() - Method in class com.hazelcast.internal.partition.NonFragmentedServiceNamespace
 
getClassId() - Method in class com.hazelcast.internal.partition.operation.AssignPartitions
 
getClassId() - Method in class com.hazelcast.internal.partition.operation.FetchPartitionStateOperation
 
getClassId() - Method in class com.hazelcast.internal.partition.operation.FinalizeMigrationOperation
 
getClassId() - Method in class com.hazelcast.internal.partition.operation.HasOngoingMigration
 
getClassId() - Method in class com.hazelcast.internal.partition.operation.MigrationCommitOperation
 
getClassId() - Method in class com.hazelcast.internal.partition.operation.MigrationOperation
 
getClassId() - Method in class com.hazelcast.internal.partition.operation.MigrationRequestOperation
 
getClassId() - Method in class com.hazelcast.internal.partition.operation.PartitionBackupReplicaAntiEntropyOperation
 
getClassId() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRequest
 
getClassId() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncResponse
 
getClassId() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRetryResponse
 
getClassId() - Method in class com.hazelcast.internal.partition.operation.PartitionStateOperation
 
getClassId() - Method in class com.hazelcast.internal.partition.operation.PartitionStateVersionCheckOperation
 
getClassId() - Method in class com.hazelcast.internal.partition.operation.PromotionCommitOperation
 
getClassId() - Method in class com.hazelcast.internal.partition.operation.PublishCompletedMigrationsOperation
 
getClassId() - Method in class com.hazelcast.internal.partition.operation.SafeStateCheckOperation
 
getClassId() - Method in class com.hazelcast.internal.partition.operation.ShutdownRequestOperation
 
getClassId() - Method in class com.hazelcast.internal.partition.operation.ShutdownResponseOperation
 
getClassId() - Method in class com.hazelcast.internal.partition.PartitionLostEventImpl
 
getClassId() - Method in class com.hazelcast.internal.partition.PartitionReplica
 
getClassId() - Method in class com.hazelcast.internal.partition.PartitionRuntimeState
 
getClassId() - Method in class com.hazelcast.internal.partition.ReplicaFragmentMigrationState
 
getClassId() - Method in class com.hazelcast.internal.partition.ReplicaMigrationEventImpl
 
getClassId() - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
 
getClassId() - Method in class com.hazelcast.internal.serialization.impl.FieldDefinitionImpl
 
getClassId() - Method in class com.hazelcast.internal.services.DistributedObjectNamespace
 
getClassId() - Method in class com.hazelcast.internal.usercodedeployment.impl.ClassData
 
getClassId() - Method in class com.hazelcast.internal.usercodedeployment.impl.operation.ClassDataFinderOperation
 
getClassId() - Method in class com.hazelcast.internal.usercodedeployment.impl.operation.DeployClassesOperation
 
getClassId() - Method in class com.hazelcast.map.eviction.LFUEvictionPolicy
 
getClassId() - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
 
getClassId() - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
 
getClassId() - Method in class com.hazelcast.map.impl.EntryEventFilter
 
getClassId() - Method in class com.hazelcast.map.impl.EntryRemovingProcessor
 
getClassId() - Method in class com.hazelcast.map.impl.EventListenerFilter
 
getClassId() - Method in class com.hazelcast.map.impl.iterator.MapEntriesWithCursor
 
getClassId() - Method in class com.hazelcast.map.impl.iterator.MapKeysWithCursor
 
getClassId() - Method in class com.hazelcast.map.impl.journal.DeserializingEventJournalMapEvent
 
getClassId() - Method in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
 
getClassId() - Method in class com.hazelcast.map.impl.journal.MapEventJournalReadOperation
 
getClassId() - Method in class com.hazelcast.map.impl.journal.MapEventJournalReadResultSetImpl
 
getClassId() - Method in class com.hazelcast.map.impl.journal.MapEventJournalSubscribeOperation
 
getClassId() - Method in class com.hazelcast.map.impl.LazyMapEntry
 
getClassId() - Method in class com.hazelcast.map.impl.LockAwareLazyMapEntry
 
getClassId() - Method in class com.hazelcast.map.impl.MapEntries
 
getClassId() - Method in class com.hazelcast.map.impl.MapKeySet
 
getClassId() - Method in class com.hazelcast.map.impl.MapPartitionLostEventFilter
 
getClassId() - Method in class com.hazelcast.map.impl.MapValueCollection
 
getClassId() - Method in class com.hazelcast.map.impl.MerkleTreeNodeEntries
 
getClassId() - Method in class com.hazelcast.map.impl.nearcache.invalidation.UuidFilter
 
getClassId() - Method in class com.hazelcast.map.impl.operation.AddIndexBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.AddIndexOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.AddIndexOperationFactory
 
getClassId() - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.AwaitMapFlushOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.ClearBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.ClearOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.ClearOperationFactory
 
getClassId() - Method in class com.hazelcast.map.impl.operation.ContainsKeyOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.ContainsValueOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.ContainsValueOperationFactory
 
getClassId() - Method in class com.hazelcast.map.impl.operation.DeleteOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.EntryBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.EntryOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.EvictAllBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.EvictAllOperationFactory
 
getClassId() - Method in class com.hazelcast.map.impl.operation.EvictBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.EvictBatchBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.EvictOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.GetAllOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.GetEntryViewOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.GetOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.IsEmptyOperationFactory
 
getClassId() - Method in class com.hazelcast.map.impl.operation.IsKeyLoadFinishedOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.IsPartitionLoadedOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.IsPartitionLoadedOperationFactory
 
getClassId() - Method in class com.hazelcast.map.impl.operation.KeyLoadStatusOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.KeyLoadStatusOperationFactory
 
getClassId() - Method in class com.hazelcast.map.impl.operation.LoadAllOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.LoadMapOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MapFetchEntriesOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MapFetchKeysOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MapFetchWithQueryOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MapFlushBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MapFlushOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MapFlushOperationFactory
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MapGetAllOperationFactory
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MapGetInvalidationMetaDataOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MapGetInvalidationMetaDataOperation.MetaDataResponse
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MapIsEmptyOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MapLoadAllOperationFactory
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MapNearCacheStateHolder
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MapReplicationOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MapReplicationStateHolder
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MapSizeOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MergeOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MergeOperationFactory
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MultipleEntryBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperationFactory
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MultipleEntryWithPredicateBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.MultipleEntryWithPredicateOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.NotifyMapFlushOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperationFactory
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperationFactory
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation.InterceptorInfo
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PutAllBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PutAllPartitionAwareOperationFactory
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PutIfAbsentOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PutIfAbsentWithExpiryOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PutOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PutTransientBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PutTransientOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PutTransientWithExpiryOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.PutWithExpiryOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.RemoveBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.RemoveFromLoadAllOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.RemoveIfSameOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.RemoveOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.ReplaceOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.SetOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.SetTtlBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.SetTtlOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.SetWithExpiryOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.SizeOperationFactory
 
getClassId() - Method in class com.hazelcast.map.impl.operation.TriggerLoadIfNeededOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.TryPutOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
 
getClassId() - Method in class com.hazelcast.map.impl.operation.WriteBehindStateHolder
 
getClassId() - Method in class com.hazelcast.map.impl.query.AggregationResult
 
getClassId() - Method in class com.hazelcast.map.impl.query.Query
 
getClassId() - Method in class com.hazelcast.map.impl.query.QueryEventFilter
 
getClassId() - Method in class com.hazelcast.map.impl.query.QueryOperation
 
getClassId() - Method in class com.hazelcast.map.impl.query.QueryPartitionOperation
 
getClassId() - Method in class com.hazelcast.map.impl.query.QueryResult
 
getClassId() - Method in class com.hazelcast.map.impl.query.QueryResultRow
 
getClassId() - Method in class com.hazelcast.map.impl.query.ResultSegment
 
getClassId() - Method in class com.hazelcast.map.impl.query.Target
 
getClassId() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
 
getClassId() - Method in class com.hazelcast.map.impl.querycache.accumulator.ConsumeAccumulatorOperation
 
getClassId() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.DestroyQueryCacheOperation
 
getClassId() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.MadePublishableOperation
 
getClassId() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.MadePublishableOperationFactory
 
getClassId() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.PublisherCreateOperation
 
getClassId() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.ReadAndResetAccumulatorOperation
 
getClassId() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.SetReadCursorOperation
 
getClassId() - Method in class com.hazelcast.map.impl.record.RecordInfo
 
getClassId() - Method in class com.hazelcast.map.impl.record.RecordReplicationInfo
 
getClassId() - Method in class com.hazelcast.map.impl.SimpleEntryView
 
getClassId() - Method in class com.hazelcast.map.impl.tx.MapTransactionLogRecord
 
getClassId() - Method in class com.hazelcast.map.impl.tx.TxnDeleteBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
 
getClassId() - Method in class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
 
getClassId() - Method in class com.hazelcast.map.impl.tx.TxnPrepareBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
 
getClassId() - Method in class com.hazelcast.map.impl.tx.TxnRollbackBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
 
getClassId() - Method in class com.hazelcast.map.impl.tx.TxnSetBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
 
getClassId() - Method in class com.hazelcast.map.impl.tx.TxnUnlockBackupOperation
 
getClassId() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
 
getClassId() - Method in class com.hazelcast.map.impl.tx.VersionedValue
 
getClassId() - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
 
getClassId() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
 
getClassId() - Method in class com.hazelcast.map.impl.wan.WanMapEntryView
 
getClassId() - Method in class com.hazelcast.multimap.impl.MultiMapEventFilter
 
getClassId() - Method in class com.hazelcast.multimap.impl.MultiMapMergeContainer
 
getClassId() - Method in class com.hazelcast.multimap.impl.MultiMapRecord
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.ClearBackupOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.ClearOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.CountOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.DeleteBackupOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.DeleteOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.EntrySetOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.EntrySetResponse
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.GetAllOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.KeySetOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.MergeBackupOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.MergeOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.MultiMapReplicationOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.PutBackupOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.PutOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllBackupOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.RemoveBackupOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.SizeOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.operations.ValuesOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
 
getClassId() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitBackupOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.txn.TxnGenerateRecordIdOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareBackupOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.txn.TxnPutBackupOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllBackupOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveBackupOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackBackupOperation
 
getClassId() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackOperation
 
getClassId() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
Returns the class ID.
getClassId() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
getClassId() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
getClassId() - Method in interface com.hazelcast.nio.serialization.IdentifiedDataSerializable
Returns type identifier for this class.
getClassId() - Method in interface com.hazelcast.nio.serialization.Portable
Returns class identifier for this portable class.
getClassId() - Method in class com.hazelcast.projection.impl.IdentityProjection
 
getClassId() - Method in class com.hazelcast.projection.impl.MultiAttributeProjection
 
getClassId() - Method in class com.hazelcast.projection.impl.SingleAttributeProjection
 
getClassId() - Method in class com.hazelcast.query.impl.CompositeValue
 
getClassId() - Method in class com.hazelcast.query.impl.MapIndexInfo
 
getClassId() - Method in class com.hazelcast.query.impl.predicates.AndPredicate
 
getClassId() - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
 
getClassId() - Method in class com.hazelcast.query.impl.predicates.BoundedRangePredicate
 
getClassId() - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
 
getClassId() - Method in class com.hazelcast.query.impl.predicates.FalsePredicate
 
getClassId() - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
 
getClassId() - Method in class com.hazelcast.query.impl.predicates.ILikePredicate
 
getClassId() - Method in class com.hazelcast.query.impl.predicates.InPredicate
 
getClassId() - Method in class com.hazelcast.query.impl.predicates.InstanceOfPredicate
 
getClassId() - Method in class com.hazelcast.query.impl.predicates.LikePredicate
 
getClassId() - Method in class com.hazelcast.query.impl.predicates.NotEqualPredicate
 
getClassId() - Method in class com.hazelcast.query.impl.predicates.NotPredicate
 
getClassId() - Method in class com.hazelcast.query.impl.predicates.OrPredicate
 
getClassId() - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
 
getClassId() - Method in class com.hazelcast.query.impl.predicates.PartitionPredicateImpl
 
getClassId() - Method in class com.hazelcast.query.impl.predicates.RegexPredicate
 
getClassId() - Method in class com.hazelcast.query.impl.predicates.SqlPredicate
 
getClassId() - Method in class com.hazelcast.query.impl.predicates.TruePredicate
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeys
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapValueCollection
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.CheckReplicaVersionOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperationFactory
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsKeyOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsValueOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.EntrySetOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.EvictionOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.GetOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.IsEmptyOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.KeySetOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.MergeOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.MergeOperationFactory
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.PutAllOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.PutAllOperationFactory
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.PutOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.RemoveOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateToCallerOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicationOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.RequestMapDataOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.SizeOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.SyncReplicatedMapDataOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.ValuesOperation
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.operation.VersionResponsePair
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
getClassId() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
getClassId() - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
 
getClassId() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllBackupOperation
 
getClassId() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
 
getClassId() - Method in class com.hazelcast.ringbuffer.impl.operations.AddBackupOperation
 
getClassId() - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
 
getClassId() - Method in class com.hazelcast.ringbuffer.impl.operations.GenericOperation
 
getClassId() - Method in class com.hazelcast.ringbuffer.impl.operations.MergeBackupOperation
 
getClassId() - Method in class com.hazelcast.ringbuffer.impl.operations.MergeOperation
 
getClassId() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
 
getClassId() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
 
getClassId() - Method in class com.hazelcast.ringbuffer.impl.operations.ReplicationOperation
 
getClassId() - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
 
getClassId() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.HashMapAdapter
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.NamedTaskDecorator
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.CancelTaskBackupOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.CancelTaskOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.DisposeBackupTaskOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.DisposeTaskOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnMemberOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnPartitionOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnPartitionOperationFactory
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetDelayOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetResultOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetStatisticsOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.IsCanceledOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.IsDoneOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.MergeBackupOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.MergeOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.ReplicationOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.ResultReadyNotifyOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.ScheduleTaskBackupOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.ScheduleTaskOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.ShutdownOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.SyncBackupStateOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.SyncStateOperation
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledRunnableAdapter
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskDescriptor
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskResult
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskStatisticsImpl
 
getClassId() - Method in class com.hazelcast.scheduledexecutor.impl.TaskDefinition
 
getClassId() - Method in class com.hazelcast.security.SimpleTokenCredentials
 
getClassId() - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
getClassId() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventEnvelope
 
getClassId() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.DeregistrationOperation
 
getClassId() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.OnJoinRegistrationOperation
 
getClassId() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.RegistrationOperation
 
getClassId() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.SendEventOperation
 
getClassId() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
 
getClassId() - Method in class com.hazelcast.spi.impl.eventservice.impl.TrueEventFilter
 
getClassId() - Method in class com.hazelcast.spi.impl.merge.AtomicLongMergingValueImpl
 
getClassId() - Method in class com.hazelcast.spi.impl.merge.AtomicReferenceMergingValueImpl
 
getClassId() - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
getClassId() - Method in class com.hazelcast.spi.impl.merge.CardinalityEstimatorMergingEntry
 
getClassId() - Method in class com.hazelcast.spi.impl.merge.CollectionMergingValueImpl
 
getClassId() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
getClassId() - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
getClassId() - Method in class com.hazelcast.spi.impl.merge.QueueMergingValueImpl
 
getClassId() - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
getClassId() - Method in class com.hazelcast.spi.impl.merge.RingbufferMergingValueImpl
 
getClassId() - Method in class com.hazelcast.spi.impl.merge.ScheduledExecutorMergingEntryImpl
 
getClassId() - Method in class com.hazelcast.spi.impl.operationservice.AbstractLocalOperation
 
getClassId() - Method in class com.hazelcast.spi.impl.operationservice.BinaryOperationFactory
 
getClassId() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
 
getClassId() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation
 
getClassId() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation.PartitionResponse
 
getClassId() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.BackupAckResponse
 
getClassId() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.CallTimeoutResponse
 
getClassId() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.ErrorResponse
 
getClassId() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.NormalResponse
 
getClassId() - Method in class com.hazelcast.spi.impl.operationservice.OperationControl
 
getClassId() - Method in class com.hazelcast.spi.impl.PortableCachePartitionLostEvent
 
getClassId() - Method in class com.hazelcast.spi.impl.PortableCollection
 
getClassId() - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
 
getClassId() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
 
getClassId() - Method in class com.hazelcast.spi.impl.PortableItemEvent
 
getClassId() - Method in class com.hazelcast.spi.impl.PortableMapPartitionLostEvent
 
getClassId() - Method in class com.hazelcast.spi.impl.PortablePartitionLostEvent
 
getClassId() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.DistributedObjectDestroyOperation
 
getClassId() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.InitializeDistributedObjectOperation
 
getClassId() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.PostJoinProxyOperation
 
getClassId() - Method in class com.hazelcast.spi.impl.SerializableList
 
getClassId() - Method in class com.hazelcast.spi.impl.tenantcontrol.NoopTenantControl
 
getClassId() - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
 
getClassId() - Method in class com.hazelcast.spi.merge.DiscardMergePolicy
 
getClassId() - Method in class com.hazelcast.spi.merge.ExpirationTimeMergePolicy
 
getClassId() - Method in class com.hazelcast.spi.merge.HigherHitsMergePolicy
 
getClassId() - Method in class com.hazelcast.spi.merge.HyperLogLogMergePolicy
 
getClassId() - Method in class com.hazelcast.spi.merge.LatestAccessMergePolicy
 
getClassId() - Method in class com.hazelcast.spi.merge.LatestUpdateMergePolicy
 
getClassId() - Method in class com.hazelcast.spi.merge.PassThroughMergePolicy
 
getClassId() - Method in class com.hazelcast.spi.merge.PutIfAbsentMergePolicy
 
getClassId() - Method in class com.hazelcast.topic.impl.PublishOperation
 
getClassId() - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicMessage
 
getClassId() - Method in class com.hazelcast.transaction.impl.operations.BroadcastTxRollbackOperation
 
getClassId() - Method in class com.hazelcast.transaction.impl.operations.CreateAllowedDuringPassiveStateTxBackupLogOperation
 
getClassId() - Method in class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
 
getClassId() - Method in class com.hazelcast.transaction.impl.operations.PurgeAllowedDuringPassiveStateTxBackupLogOperation
 
getClassId() - Method in class com.hazelcast.transaction.impl.operations.PurgeTxBackupLogOperation
 
getClassId() - Method in class com.hazelcast.transaction.impl.operations.ReplicateAllowedDuringPassiveStateTxBackupLogOperation
 
getClassId() - Method in class com.hazelcast.transaction.impl.operations.ReplicateTxBackupLogOperation
 
getClassId() - Method in class com.hazelcast.transaction.impl.operations.RollbackAllowedDuringPassiveStateTxBackupLogOperation
 
getClassId() - Method in class com.hazelcast.transaction.impl.operations.RollbackTxBackupLogOperation
 
getClassId() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionBackupOperation
 
getClassId() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
 
getClassId() - Method in class com.hazelcast.transaction.impl.xa.operations.CollectRemoteTransactionsOperation
 
getClassId() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionBackupOperation
 
getClassId() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
 
getClassId() - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionBackupOperation
 
getClassId() - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionOperation
 
getClassId() - Method in class com.hazelcast.transaction.impl.xa.operations.XaReplicationOperation
 
getClassId() - Method in class com.hazelcast.transaction.impl.xa.XATransactionDTO
 
getClassId() - Method in class com.hazelcast.version.MemberVersion
 
getClassId() - Method in class com.hazelcast.version.Version
 
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.client.impl.clientside.ClientDynamicClusterConfig
 
getClassLoader() - Method in class com.hazelcast.config.Config
Returns the class-loader that will be used in serialization.
getClassLoader() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getClassLoader() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
 
getClassLoader() - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService.Builder
 
getClassLoader() - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
getClassLoader() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
getClassLoader() - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
 
getClassLoader() - Method in interface com.hazelcast.nio.ObjectDataInput
Returns class loader that internally used for objects.
getClassName() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
getClassName() - Method in class com.hazelcast.client.impl.protocol.exception.ErrorHolder
 
getClassName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.ListenerConfigHolder
 
getClassName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
getClassName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.PredicateConfigHolder
 
getClassName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueueStoreConfigHolder
 
getClassName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.RingbufferStoreConfigHolder
 
getClassName() - Method in class com.hazelcast.config.AbstractWanPublisherConfig
Returns the name of the class implementing WanReplicationPublisher.
getClassName() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
getClassName() - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
getClassName() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
getClassName() - Method in class com.hazelcast.config.GlobalSerializerConfig
 
getClassName() - Method in class com.hazelcast.config.ListenerConfig
Returns the name of the class of the EventListener.
getClassName() - Method in class com.hazelcast.config.LoginModuleConfig
 
getClassName() - Method in class com.hazelcast.config.MapStoreConfig
Returns the name of the MapStore implementation class
getClassName() - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
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.RingbufferStoreConfig
 
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
Returns the name of the SocketInterceptor implementation class.
getClassName() - Method in class com.hazelcast.config.WanConsumerConfig
Returns the fully qualified class name of the class implementing WanReplicationConsumer.
getClassNames() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
getClassType() - Method in interface com.hazelcast.nio.serialization.TypedDataSerializable
 
getClassVersion(int, int) - Method in interface com.hazelcast.internal.serialization.PortableContext
 
getClassVersion() - Method in interface com.hazelcast.nio.serialization.VersionedPortable
Returns version for this Portable class
getClearExpiredRecordsTask() - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getClient() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getClient() - Method in class com.hazelcast.client.impl.proxy.txn.TransactionContextProxy
 
getClient() - Method in class com.hazelcast.client.impl.proxy.txn.xa.XATransactionContextProxy
 
getClient() - Method in class com.hazelcast.client.impl.spi.ClientProxy
 
getClient() - Method in interface com.hazelcast.client.impl.spi.ClientTransactionContext
 
getClient() - Method in class com.hazelcast.client.impl.spi.impl.ClientTransactionManagerServiceImpl
 
getClientBlockingExecutorMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getClientBlockUnmappedActions() - Method in class com.hazelcast.config.SecurityConfig
 
getClientBlockUnmappedActions() - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
getClientCallId() - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
getClientClusterService() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getClientConfig() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getClientConfig() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getClientConfig() - Method in class com.hazelcast.client.impl.spi.ClientContext
 
getClientConfigs() - Method in class com.hazelcast.client.config.ClientFailoverConfig
 
getClientDiscoveryService() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getClientEndpointCount() - Method in interface com.hazelcast.client.impl.ClientEngine
 
getClientEndpointCount() - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
getClientEndpointCount() - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
getClientEndpointCount() - Method in class com.hazelcast.internal.jmx.ClientEngineMBean
 
getClientEngine() - Method in class com.hazelcast.instance.impl.Node
 
getClientEngine() - Method in interface com.hazelcast.internal.nio.IOService
 
getClientEngine() - Method in class com.hazelcast.internal.nio.NodeIOService
 
getClientEngineMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getClientExceptionFactory() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getClientExceptions() - Method in interface com.hazelcast.client.impl.ClientEngine
 
getClientExceptions() - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
getClientExceptions() - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
getClientExecutionService() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getClientExecutorMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getClientExtension() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getClientIcmpPingConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
ICMP ping is used to detect if machine that a remote hazelcast member runs on alive or not
getClientMessage() - Method in class com.hazelcast.client.impl.protocol.ClientMessageReader
 
getClientMessage() - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocation
 
getClientName() - Method in class com.hazelcast.client.config.ClientConfig
Returns the client name.
getClientName() - Method in class com.hazelcast.client.impl.clientside.CandidateClusterContext
 
getClientName() - Method in interface com.hazelcast.client.impl.spi.ClientTransactionManagerService
 
getClientName() - Method in class com.hazelcast.client.impl.spi.impl.ClientTransactionManagerServiceImpl
 
getClientPartitionService() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getClientPermissionConfigs() - Method in class com.hazelcast.config.SecurityConfig
 
getClientPermissionConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
Returns existing client permissions as an unmodifiable Set.
getClientPermissionConfigs() - Method in interface com.hazelcast.security.SecurityService
Returns latest client permission configuration.
getClientPolicyConfig() - Method in class com.hazelcast.config.SecurityConfig
 
getClientPolicyConfig() - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
getClientProxyClass() - Method in interface com.hazelcast.client.impl.spi.ClientProxyDescriptor
 
getClientProxyFactory(String) - Method in class com.hazelcast.client.impl.spi.ProxyManager
 
getClientQueryExecutorMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getClientRealm() - Method in class com.hazelcast.config.SecurityConfig
 
getClientRealm() - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
getClients() - Method in interface com.hazelcast.client.impl.ClientEngine
 
getClients() - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
getClients() - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
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.clientside.HazelcastClientInstanceImpl
 
getClientService() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getClientService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the client service of this Hazelcast instance.
getClientService() - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getClientService() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getClientStatistics() - Method in interface com.hazelcast.client.impl.ClientEndpoint
 
getClientStatistics() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
getClientStatistics() - Method in interface com.hazelcast.client.impl.ClientEngine
The statistics is a String that is composed of key=value pairs separated by ',' .
getClientStatistics() - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
getClientStatistics() - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
getClientStats() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
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 interface com.hazelcast.client.Client
Returns the type of this client.
getClientType() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
getClientType() - Method in class com.hazelcast.client.impl.ClientEvent
 
getClientType() - Method in class com.hazelcast.client.impl.ClientImpl
 
getClientType() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
 
getClientType() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
 
getClientType() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationMessageTask
 
getClientUuid() - Method in interface com.hazelcast.client.impl.connection.ClientConnectionManager
 
getClientUuid() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
getCloseCause() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
getCloseCause() - Method in interface com.hazelcast.internal.nio.Connection
Gets the cause this Connection was closed.
getCloseCause() - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
getCloseReason() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
getCloseReason() - Method in interface com.hazelcast.internal.nio.Connection
Gets the reason this Connection was closed.
getCloseReason() - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
getCloudConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
getCluster() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getCluster() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getCluster() - Method in class com.hazelcast.cluster.InitialMembershipEvent
Returns the cluster of the event.
getCluster() - Method in class com.hazelcast.cluster.MembershipEvent
Returns the cluster of the event.
getCluster() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the Cluster that this Hazelcast instance is part of.
getCluster() - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getCluster() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getClusterClock() - Method in interface com.hazelcast.internal.cluster.ClusterService
Returns the ClusterClock of the cluster.
getClusterClock() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getClusterConnection() - Method in interface com.hazelcast.client.impl.connection.nio.ClusterConnectorService
 
getClusterConnection() - Method in class com.hazelcast.client.impl.connection.nio.ClusterConnectorServiceImpl
 
getClusterConnectorService() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getClusterConnectorService() - Method in class com.hazelcast.client.impl.spi.ClientContext
 
getClusterDataRecoveryPolicy() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Returns the policy to be used when the cluster is started
getClusterHeartbeatManager() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getClusterHotRestartStatus() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
getClusterHotRestartStatus() - Method in interface com.hazelcast.monitor.MemberState
 
getClusterId() - Method in interface com.hazelcast.internal.cluster.ClusterService
Returns UUID for the cluster.
getClusterId() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getClusterJoinManager() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getClusterName() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getClusterName() - Method in class com.hazelcast.config.Config
Returns the cluster name uniquely identifying the hazelcast cluster.
getClusterName() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the cluster name used as a publisher cluster name for authentication on the target endpoint.
getClusterName() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getClusterName() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getClusterName() - Method in class com.hazelcast.internal.management.TimedMemberState
 
getClusterName() - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
getClusterName() - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
 
getClusterNames() - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
 
getClusterNames() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
 
getClusterNames() - Method in interface com.hazelcast.wan.impl.InternalWanReplicationEvent
Returns the set of cluster names on which this event has already been processed.
getClusterService() - Method in interface com.hazelcast.client.impl.ClientEngine
 
getClusterService() - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
getClusterService() - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
getClusterService() - Method in class com.hazelcast.client.impl.spi.ClientContext
 
getClusterService() - Method in class com.hazelcast.instance.impl.Node
 
getClusterService() - Method in interface com.hazelcast.spi.impl.NodeEngine
Gets the ClusterService.
getClusterService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getClusterStartTime() - Method in class com.hazelcast.internal.cluster.impl.ClusterClockImpl
 
getClusterState() - Method in class com.hazelcast.client.impl.proxy.ClientClusterProxy
 
getClusterState() - Method in interface com.hazelcast.cluster.Cluster
Returns the state of the cluster.
getClusterState() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getClusterState() - Method in class com.hazelcast.monitor.impl.NodeStateImpl
 
getClusterState() - Method in interface com.hazelcast.monitor.NodeState
 
getClusterStateManager() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getClusterStateOrNull() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateChange
 
GetClusterStateRequest - Class in com.hazelcast.internal.management.request
Request coming from Management Center for getting the ClusterState
GetClusterStateRequest() - Constructor for class com.hazelcast.internal.management.request.GetClusterStateRequest
 
getClusterTime() - Method in class com.hazelcast.client.impl.proxy.ClientClusterProxy
 
getClusterTime() - Method in interface com.hazelcast.client.impl.spi.ClientClusterService
Returns the cluster-time.
getClusterTime() - Method in class com.hazelcast.client.impl.spi.impl.ClientClusterServiceImpl
 
getClusterTime() - Method in interface com.hazelcast.cluster.Cluster
Returns the cluster-wide time in milliseconds.
getClusterTime() - Method in interface com.hazelcast.internal.cluster.ClusterClock
Returns the cluster-time in milliseconds.
getClusterTime() - Method in class com.hazelcast.internal.cluster.impl.ClusterClockImpl
 
getClusterTime() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getClusterTime() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getClusterUpTime() - Method in interface com.hazelcast.internal.cluster.ClusterClock
Returns the cluster up-time in milliseconds.
getClusterUpTime() - Method in class com.hazelcast.internal.cluster.impl.ClusterClockImpl
 
getClusterVersion() - Method in class com.hazelcast.client.impl.proxy.ClientClusterProxy
 
getClusterVersion() - Method in interface com.hazelcast.cluster.Cluster
The cluster version indicates the operating version of the cluster.
getClusterVersion() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getClusterVersion() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateManager
 
getClusterVersion() - Method in class com.hazelcast.internal.cluster.impl.SplitBrainJoinMessage
 
getClusterVersion() - Method in class com.hazelcast.monitor.impl.NodeStateImpl
 
getClusterVersion() - Method in interface com.hazelcast.monitor.NodeState
 
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
 
getCode() - Method in enum com.hazelcast.internal.management.events.EventMetadata.EventType
 
getCodec() - Method in class com.hazelcast.client.impl.spi.impl.listener.ClientEventRegistration
 
getCodec() - Method in class com.hazelcast.client.impl.spi.impl.listener.ClientRegistrationKey
 
getCollectedContainers() - Method in class com.hazelcast.spi.impl.merge.AbstractContainerCollector
Returns the collected containers by partition ID.
getCollection() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
getCollection() - Method in class com.hazelcast.collection.impl.list.ListContainer
 
getCollection() - Method in class com.hazelcast.collection.impl.set.SetContainer
 
getCollection() - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
 
getCollection() - Method in class com.hazelcast.collection.impl.txnlist.TransactionalListProxy
 
getCollection() - Method in class com.hazelcast.collection.impl.txnset.TransactionalSetProxy
 
getCollection(boolean) - Method in class com.hazelcast.multimap.impl.MultiMapValue
 
getCollection() - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
 
getCollection() - Method in class com.hazelcast.spi.impl.PortableCollection
 
getCollection() - Method in class com.hazelcast.spi.impl.SerializableList
 
getCollectionIntervalSeconds() - Method in class com.hazelcast.config.MetricsConfig
Returns the metrics collection interval.
getColumn() - Method in exception com.hazelcast.internal.json.ParseException
Deprecated.
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
 
getCommand() - Method in class com.hazelcast.scheduledexecutor.impl.TaskDefinition
 
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, EntryConverter) - Constructor for class com.hazelcast.internal.ascii.memcache.GetCommandProcessor
 
getCommitId() - Method in class com.hazelcast.instance.BuildInfo
 
getCommitIndex() - Method in exception com.hazelcast.cp.internal.raft.exception.MismatchingGroupMembersCommitIndexException
 
getCommitIndexAdvanceCountToSnapshot() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getCommittedHeap() - Method in class com.hazelcast.internal.memory.DefaultMemoryStats
 
getCommittedHeap() - Method in interface com.hazelcast.internal.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
 
getCommittedMembers() - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Returns the last committed member list of the raft group this node belongs to.
getCommittedMembers() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
getCommittedNative() - Method in class com.hazelcast.internal.memory.DefaultMemoryStats
 
getCommittedNative() - Method in interface com.hazelcast.internal.memory.MemoryStats
Returns the amount of native memory in bytes that is committed for current HazelcastInstance to use.
getCommittedNative() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
getComparator() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.EvictionConfigHolder
 
getComparator() - Method in class com.hazelcast.config.EvictionConfig
Returns the instance of the configured EvictionPolicyComparator implementation.
getComparator() - Method in interface com.hazelcast.internal.eviction.EvictionConfiguration
Gets instance of the configured EvictionPolicyComparator implementation.
getComparator() - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
 
getComparator() - Method in interface com.hazelcast.query.PagingPredicate
Returns the comparator used by this predicate (if any).
getComparatorClassName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.EvictionConfigHolder
 
getComparatorClassName() - Method in class com.hazelcast.config.EvictionConfig
Returns the class name of the configured EvictionPolicyComparator implementation.
getComparatorClassName() - Method in interface com.hazelcast.internal.eviction.EvictionConfiguration
Gets the class name of the configured EvictionPolicyComparator implementation.
getCompleted() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
getCompletedMigrations() - Method in class com.hazelcast.internal.partition.impl.MigrationStats
Returns the number of completed migrations on the latest repartitioning round.
getCompletedMigrations() - Method in class com.hazelcast.internal.partition.MigrationStateImpl
 
getCompletedMigrations() - Method in class com.hazelcast.internal.partition.PartitionRuntimeState
 
getCompletedMigrations() - Method in interface com.hazelcast.partition.MigrationState
Returns the number of completed migrations in the migration plan.
getCompletedTaskCount() - Method in class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
getCompletedTaskCount() - Method in interface com.hazelcast.internal.util.executor.ManagedExecutorService
 
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.
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.CachePutAllOperation
 
getCompletionId() - Method in interface com.hazelcast.cache.impl.operation.MutableOperation
 
getCompletionId() - Method in class com.hazelcast.cache.impl.operation.MutatingCacheOperation
 
getComponentConverter(int) - Method in class com.hazelcast.query.impl.CompositeConverter
 
getComponents() - Method in class com.hazelcast.query.impl.AbstractIndex
 
getComponents() - Method in class com.hazelcast.query.impl.CompositeValue
Returns the components of this composite value.
getComponents() - Method in interface com.hazelcast.query.impl.Index
 
getComponents(IndexConfig) - Static method in class com.hazelcast.query.impl.IndexUtils
 
getCompositeIndexes() - Method in class com.hazelcast.query.impl.Indexes
Returns all the composite indexes known to this indexes instance.
getConcurrencyDetection() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getConcurrencyDetection() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
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 class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getConfig() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AbstractAddConfigMessageTask
 
getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddCacheConfigMessageTask
 
getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddCardinalityEstimatorConfigMessageTask
 
getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddDurableExecutorConfigMessageTask
 
getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddExecutorConfigMessageTask
 
getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddFlakeIdGeneratorConfigMessageTask
 
getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddListConfigMessageTask
 
getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddMapConfigMessageTask
 
getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddMultiMapConfigMessageTask
 
getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddQueueConfigMessageTask
 
getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddReliableTopicConfigMessageTask
 
getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddReplicatedMapConfigMessageTask
 
getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddRingbufferConfigMessageTask
 
getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddScheduledExecutorConfigMessageTask
 
getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddSetConfigMessageTask
 
getConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddTopicConfigMessageTask
 
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.cp.internal.RaftService
 
getConfig() - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getConfig() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getConfig() - Method in class com.hazelcast.instance.impl.Node
 
getConfig(ConfigPatternMatcher, Map<String, T>, String, Class) - Static method in class com.hazelcast.internal.config.ConfigUtils
Returns a config for the given name, creating one if necessary and adding it to the collection of known configurations.
getConfig(ConfigPatternMatcher, Map<String, T>, String, Class, BiConsumer<T, String>) - Static method in class com.hazelcast.internal.config.ConfigUtils
Similar to ConfigUtils.getConfig(ConfigPatternMatcher, Map, String, Class) This method is introduced specifically for solving problem of EventJournalConfig use ConfigUtils.getConfig(ConfigPatternMatcher, Map, String, Class) along with NamedConfig where possible
getConfig(String, String, ConfigSupplier<T>) - Method in interface com.hazelcast.internal.dynamicconfig.search.Searcher
Get configuration for data structure with the given name
getConfig() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getConfig() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getConfig() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getConfig() - Method in class com.hazelcast.internal.jmx.QueueMBean
 
getConfig() - Method in class com.hazelcast.internal.jmx.ReliableTopicMBean
 
getConfig() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
getConfig() - Method in class com.hazelcast.internal.jmx.TopicMBean
 
getConfig() - Method in class com.hazelcast.internal.management.dto.AliasedDiscoveryConfigDTO
 
getConfig() - Method in class com.hazelcast.internal.management.dto.CustomWanPublisherConfigDTO
 
getConfig() - Method in class com.hazelcast.internal.management.dto.DiscoveryConfigDTO
 
getConfig() - Method in class com.hazelcast.internal.management.dto.DiscoveryStrategyConfigDTO
 
getConfig() - Method in class com.hazelcast.internal.management.dto.MapConfigDTO
 
getConfig() - Method in class com.hazelcast.internal.management.dto.WanBatchReplicationPublisherConfigDTO
 
getConfig() - Method in class com.hazelcast.internal.management.dto.WanConsumerConfigDTO
 
getConfig() - Method in class com.hazelcast.internal.management.dto.WanReplicationConfigDTO
 
getConfig() - Method in class com.hazelcast.internal.management.dto.WanSyncConfigDTO
 
getConfig() - Method in class com.hazelcast.query.impl.AbstractIndex
 
getConfig() - Method in interface com.hazelcast.query.impl.Index
 
getConfig() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
 
getConfig() - Method in interface com.hazelcast.spi.impl.NodeEngine
Returns the Config that was used to create the HazelcastInstance.
getConfig() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getConfig() - Method in class com.hazelcast.spi.properties.HazelcastProperties
 
getConfig() - Method in class com.hazelcast.splitbrainprotection.impl.SplitBrainProtectionImpl
 
getConfigByTag(ClientNetworkConfig, String) - Static method in class com.hazelcast.client.config.ClientAliasedDiscoveryConfigUtils
Gets the AliasedDiscoveryConfig from config by tag.
getConfigByTag(JoinConfig, String) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Gets the AliasedDiscoveryConfig from config by tag.
getConfigByTag(WanBatchReplicationPublisherConfig, String) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Gets the AliasedDiscoveryConfig from config by tag.
getConfigCheck() - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
 
getConfigClassLoader() - Method in class com.hazelcast.instance.impl.Node
 
getConfigClassLoader() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
getConfigClassLoader() - Method in interface com.hazelcast.spi.impl.NodeEngine
Returns the Config ClassLoader.
getConfigClassLoader() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getConfigObject() - Method in class com.hazelcast.config.ServiceConfig
 
getConfigPatternMatcher() - Method in class com.hazelcast.client.config.ClientConfig
Returns the pattern matcher which is used to match item names to configuration objects.
getConfigPatternMatcher() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getConfigPatternMatcher() - Method in class com.hazelcast.config.Config
Returns the pattern matcher which is used to match item names to configuration objects.
getConfigPatternMatcher() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getConfigRoot() - Method in class com.hazelcast.client.config.YamlClientConfigBuilder
 
getConfigRoot() - Method in class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
 
getConfigRoot() - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
 
getConfigRoot() - Method in class com.hazelcast.config.YamlConfigBuilder
 
getConfigs() - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
getConfigSource() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getConfigType() - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
getConfigType() - Method in class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
 
getConfigType() - Method in class com.hazelcast.config.AbstractXmlConfigBuilder
 
getConfigType() - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
getConfigType() - Method in class com.hazelcast.config.XmlConfigBuilder
 
getConfiguration(Class<C>) - Method in class com.hazelcast.cache.impl.CacheProxy
 
getConfiguration(Class<C>) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
getConfigurationFile() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getConfigurationFile() - Method in class com.hazelcast.config.AbstractConfigLocator
 
getConfigurationFile() - Method in class com.hazelcast.config.Config
Returns the File to the declarative configuration, which has been parsed to create this Config instance.
getConfigurationFile() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getConfigurationMembers(Config) - Static method in class com.hazelcast.internal.cluster.impl.TcpIpJoiner
 
getConfigurationMembers(TcpIpConfig) - Static method in class com.hazelcast.internal.cluster.impl.TcpIpJoiner
 
getConfigurationProperties() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategyFactory
Returns a set of the expected configuration properties.
getConfigurationProperties() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategyFactory
 
getConfigurationService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getConfigurationUrl() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getConfigurationUrl() - Method in class com.hazelcast.config.AbstractConfigLocator
 
getConfigurationUrl() - Method in class com.hazelcast.config.Config
Returns the URL to the declarative configuration, which has been parsed to create this Config instance.
getConfigurationUrl() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getConfiguredString() - Static method in enum com.hazelcast.internal.networking.nio.SelectorMode
 
getConfiguredValue() - Static method in enum com.hazelcast.internal.networking.nio.SelectorMode
 
getConn() - Method in class com.hazelcast.internal.nio.Packet
Gets the Connection this Packet was send with.
getConnectedClients() - Method in interface com.hazelcast.client.ClientService
Returns all connected clients to this member.
getConnectedClients() - Method in class com.hazelcast.client.impl.ClientServiceProxy
 
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.impl.ClientEngine
Returns Map which contains number of connected clients to the cluster.
getConnectedClientStats() - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
getConnectedClientStats() - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
getConnectedServerVersion() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
getConnection() - Method in interface com.hazelcast.client.impl.ClientEndpoint
 
getConnection() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
getConnection() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
getConnection() - Method in class com.hazelcast.client.impl.proxy.txn.TransactionContextProxy
 
getConnection() - Method in class com.hazelcast.client.impl.proxy.txn.xa.XATransactionContextProxy
 
getConnection() - Method in interface com.hazelcast.client.impl.spi.ClientTransactionContext
 
getConnection() - Method in class com.hazelcast.internal.ascii.rest.HttpPostCommand
 
getConnection(Address) - Method in interface com.hazelcast.internal.nio.EndpointManager
Gets the connection for a given address.
getConnection(Address) - Method in class com.hazelcast.internal.nio.tcp.ClientViewUnifiedEndpointManager
 
getConnection(Address) - Method in class com.hazelcast.internal.nio.tcp.MemberViewUnifiedEndpointManager
 
getConnection(Address) - Method in class com.hazelcast.internal.nio.tcp.TcpIpEndpointManager
 
getConnection(Address) - Method in class com.hazelcast.internal.nio.tcp.TextViewUnifiedEndpointManager
 
getConnection() - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
getConnectionCount() - Method in class com.hazelcast.internal.jmx.NetworkingServiceMBean
 
getConnectionId() - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
getConnectionManager() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getConnectionManager() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
getConnectionManager() - Method in class com.hazelcast.client.impl.spi.ClientContext
 
getConnectionManagerBean() - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
 
getConnectionMonitorInterval() - Method in interface com.hazelcast.internal.nio.IOService
 
getConnectionMonitorInterval() - Method in class com.hazelcast.internal.nio.NodeIOService
 
getConnectionMonitorMaxFaults() - Method in interface com.hazelcast.internal.nio.IOService
 
getConnectionMonitorMaxFaults() - Method in class com.hazelcast.internal.nio.NodeIOService
 
getConnectionRetryConfig() - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
Connection Retry Config is controls the period among the retries and when should a client gave up retrying.
getConnections() - Method in interface com.hazelcast.internal.nio.AggregateEndpointManager
Returns all connections that have been successfully established by the underlying EndpointManagers.
getConnections() - Method in class com.hazelcast.internal.nio.DefaultAggregateEndpointManager
 
getConnections() - Method in interface com.hazelcast.internal.nio.EndpointManager
Returns connections that have been successfully established (ie.
getConnections() - Method in class com.hazelcast.internal.nio.tcp.ClientViewUnifiedEndpointManager
 
getConnections() - Method in class com.hazelcast.internal.nio.tcp.MemberViewUnifiedEndpointManager
 
getConnections() - Method in class com.hazelcast.internal.nio.tcp.TcpIpEndpointManager
 
getConnections() - Method in class com.hazelcast.internal.nio.tcp.TextViewUnifiedEndpointManager
 
getConnections() - Method in class com.hazelcast.internal.nio.UnifiedAggregateEndpointManager
 
getConnectionStrategy() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getConnectionStrategy() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
getConnectionStrategyConfig() - Method in class com.hazelcast.client.config.ClientConfig
 
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
getConnectionTimeoutSeconds() - Method in class com.hazelcast.config.TcpIpConfig
Returns the connection timeout.
getConsistencyCheckStrategy() - Method in class com.hazelcast.config.WanSyncConfig
Returns the strategy for checking consistency of data between source and target cluster.
getConstructors() - Static method in class com.hazelcast.map.impl.MapListenerAdaptors
 
getContainer() - Method in class com.hazelcast.collection.impl.queue.operations.QueueOperation
 
getContainer() - Method in class com.hazelcast.collection.impl.queue.QueueItem
 
getContainer(String) - Method in class com.hazelcast.scheduledexecutor.impl.AbstractScheduledExecutorContainerHolder
 
getContainer() - Method in class com.hazelcast.scheduledexecutor.impl.operations.AbstractSchedulerOperation
 
getContainer(String) - Method in interface com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainerHolder
 
getContainerConstructorFunction() - Method in class com.hazelcast.scheduledexecutor.impl.AbstractScheduledExecutorContainerHolder
 
getContainerConstructorFunction() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorMemberBin
 
getContainerConstructorFunction() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorPartition
 
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
 
getContainerOrNull(int, ObjectNamespace) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
Returns the ringbuffer container if it already exists for the given partitionId and namespace.
getContainers() - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
getContainers() - Method in class com.hazelcast.scheduledexecutor.impl.AbstractScheduledExecutorContainerHolder
 
getContentType() - Method in class com.hazelcast.internal.ascii.rest.RestValue
 
getContext() - Method in class com.hazelcast.client.impl.spi.ClientProxy
 
getContext() - Method in class com.hazelcast.client.impl.spi.ProxyManager
 
getContext() - Method in class com.hazelcast.map.impl.querycache.publisher.DefaultPublisherContext
 
getContext() - Method in interface com.hazelcast.map.impl.querycache.publisher.PublisherContext
Returns QueryCacheContext on this node.
getContext() - Method in class com.hazelcast.map.impl.querycache.subscriber.MapSubscriberRegistry
 
getContext() - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRequest
 
getContext() - Method in class com.hazelcast.map.impl.querycache.subscriber.SubscriberAccumulatorFactory
 
getContext() - Method in class com.hazelcast.map.impl.querycache.subscriber.SubscriberRegistry
 
getContext(String) - Method in class com.hazelcast.query.impl.getters.JsonGetterContextCache
Returns an existing or newly created context for given query path.
getContextType() - Method in class com.hazelcast.cache.impl.tenantcontrol.CacheDestroyEventContext
 
getContextType() - Method in interface com.hazelcast.spi.tenantcontrol.DestroyEventContext
 
getConverter() - Method in class com.hazelcast.query.impl.AbstractIndex
 
getConverter() - Method in enum com.hazelcast.query.impl.AttributeType
 
getConverter() - Method in interface com.hazelcast.query.impl.Index
 
getConverter(String) - Method in class com.hazelcast.query.impl.Indexes
 
getCorrelationId() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
getCost() - Method in interface com.hazelcast.core.EntryView
Returns the cost (in bytes) of the entry.
getCost() - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
getCost() - Method in interface com.hazelcast.map.impl.record.Record
Returns heap cost of this record in bytes.
getCost() - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
 
getCost() - Method in class com.hazelcast.map.impl.SimpleEntryView
 
getCost() - Method in class com.hazelcast.map.impl.wan.WanMapEntryView
 
getCost() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
getCost() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
getCost() - Method in interface com.hazelcast.spi.merge.MergingCosts
Returns the memory cost of the merge data.
getCount() - Method in class com.hazelcast.cache.impl.CacheEntryIterationResult
 
getCount() - Method in class com.hazelcast.cache.impl.CacheKeyIterationResult
 
getCount() - Method in class com.hazelcast.client.cp.internal.datastructures.countdownlatch.CountDownLatchProxy
 
getCount() - Method in interface com.hazelcast.cp.ICountDownLatch
Returns the current count.
getCount() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.proxy.CountDownLatchProxy
 
getCount() - Method in class com.hazelcast.internal.jmx.CountDownLatchMBean
 
getCount() - Method in class com.hazelcast.internal.metrics.managementcenter.ManagementCenterPublisher
 
getCount() - Method in class com.hazelcast.map.impl.iterator.MapKeysWithCursor
 
getCountDownLatch(String) - Method in class com.hazelcast.client.cp.internal.CPSubsystemImpl
 
getCountDownLatch(String) - Method in interface com.hazelcast.cp.CPSubsystem
Returns a proxy for an ICountDownLatch instance created on CP Subsystem.
getCountDownLatch(String) - Method in class com.hazelcast.cp.internal.CPSubsystemImpl
 
getCounter(String) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterService
Returns the counter with the given name.
GetCountMessageTask - Class in com.hazelcast.cp.internal.datastructures.countdownlatch.client
Client message task for GetCountOp
GetCountMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.client.GetCountMessageTask
 
GetCountOp - Class in com.hazelcast.cp.internal.datastructures.countdownlatch.operation
GetCountOp() - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.GetCountOp
 
GetCountOp(String) - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.GetCountOp
 
getCPGroup(String) - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Returns the active CP group with the given name.
getCPGroup(CPGroupId) - Method in class com.hazelcast.cp.internal.RaftService
 
getCPGroup(String) - Method in class com.hazelcast.cp.internal.RaftService
 
getCPGroupIds() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Returns all active CP group ids.
getCPGroupIds() - Method in class com.hazelcast.cp.internal.RaftService
 
getCPGroupPartitionId(CPGroupId) - Method in class com.hazelcast.cp.internal.RaftService
 
getCPGroupPartitionId(CPGroupId, int) - Static method in class com.hazelcast.cp.internal.RaftService
 
getCPMember(RaftEndpoint) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Returns the CP member instance of the given Raft endpoint
getCPMember(RaftEndpoint) - Method in class com.hazelcast.cp.internal.RaftInvocationManager
 
getCPMember(UUID) - Method in class com.hazelcast.spi.impl.operationservice.impl.RaftInvocationContext
 
getCPMemberCount() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the number of CP members that will initialize CP Subsystem.
getCPMembers() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Returns the current list of CP members
getCPMembers() - Method in class com.hazelcast.cp.internal.RaftService
 
getCpMemberUuid() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
getCpMemberUuid() - Method in interface com.hazelcast.monitor.MemberState
Returns the local CP member's UUID if this Hazelcast member is part of the CP subsystem, returns null otherwise.
getCPMetadataStore() - Method in interface com.hazelcast.cp.internal.persistence.CPPersistenceService
Returns the utility that is used for storing CPMember identity of the local Hazelcast member.
getCPMetadataStore() - Method in class com.hazelcast.cp.internal.persistence.NopCPPersistenceService
 
getCPPersistenceService() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
getCPPersistenceService() - Method in interface com.hazelcast.instance.impl.NodeExtension
Returns CP persistence service.
getCPSessionManagementService() - Method in class com.hazelcast.client.cp.internal.CPSubsystemImpl
 
getCPSessionManagementService() - Method in interface com.hazelcast.cp.CPSubsystem
Returns the CPSessionManagementService of this Hazelcast instance.
getCPSessionManagementService() - Method in class com.hazelcast.cp.internal.CPSubsystemImpl
 
getCPSubsystem() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getCPSubsystem() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getCPSubsystem() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the CP subsystem that offers a set of in-memory linearizable data structures
getCPSubsystem() - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getCPSubsystem() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getCPSubsystemConfig() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getCPSubsystemConfig() - Method in class com.hazelcast.config.Config
Get current configuration for the CP subsystem
getCPSubsystemConfig() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getCPSubsystemManagementService() - Method in class com.hazelcast.client.cp.internal.CPSubsystemImpl
 
getCPSubsystemManagementService() - Method in interface com.hazelcast.cp.CPSubsystem
Returns the CPSubsystemManagementService of this Hazelcast instance.
getCPSubsystemManagementService() - Method in class com.hazelcast.cp.internal.CPSubsystemImpl
 
getCRDTReplicationConfig() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getCRDTReplicationConfig() - Method in class com.hazelcast.config.Config
 
getCRDTReplicationConfig() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getCreationTime() - Method in interface com.hazelcast.cache.CacheStatistics
Gets the cache creation time.
getCreationTime() - Method in class com.hazelcast.cache.impl.CacheEventContext
 
getCreationTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
getCreationTime() - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
 
getCreationTime() - Method in class com.hazelcast.cache.impl.merge.entry.LazyCacheEntryView
 
getCreationTime() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
getCreationTime() - Method in class com.hazelcast.collection.impl.collection.CollectionItem
 
getCreationTime() - Method in class com.hazelcast.collection.impl.queue.QueueItem
 
getCreationTime() - Method in interface com.hazelcast.core.EntryView
Returns the creation time of the entry.
getCreationTime() - Method in interface com.hazelcast.internal.eviction.Evictable
Gets the creation time of this Evictable in milliseconds.
getCreationTime() - Method in interface com.hazelcast.internal.eviction.EvictableEntryView
Gets the creation time of this EvictableEntryView in milliseconds.
getCreationTime() - Method in class com.hazelcast.internal.eviction.ExpiredKey
 
getCreationTime() - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.CacheBrowserEntryView
 
getCreationTime() - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
getCreationTime() - Method in class com.hazelcast.internal.nearcache.impl.store.HeapNearCacheRecordMap.NearCacheEvictableSamplingEntry
 
getCreationTime() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
getCreationTime() - Method in interface com.hazelcast.map.impl.querycache.event.QueryCacheEventData
 
getCreationTime() - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
getCreationTime() - Method in interface com.hazelcast.map.impl.record.Record
 
getCreationTime() - Method in class com.hazelcast.map.impl.record.RecordInfo
 
getCreationTime() - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
 
getCreationTime() - Method in class com.hazelcast.map.impl.SimpleEntryView
 
getCreationTime() - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
 
getCreationTime() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
 
getCreationTime() - Method in class com.hazelcast.map.impl.wan.WanMapEntryView
 
getCreationTime() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
getCreationTime() - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
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.LocalFlakeIdGeneratorStatsImpl
 
getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
 
getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
 
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.LocalPNCounterStatsImpl
 
getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalTopicStatsImpl
 
getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalWanStatsImpl
 
getCreationTime() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
getCreationTime() - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Returns the creation time.
getCreationTime() - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
getCreationTime() - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Returns the creation time of the index.
getCreationTime() - Method in class com.hazelcast.monitor.impl.WanSyncStateImpl
 
getCreationTime() - Method in interface com.hazelcast.monitor.LocalInstanceStats
Returns the creation time of this distributed object instance on this member.
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 Near Cache on this member.
getCreationTime() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
getCreationTime() - Method in class com.hazelcast.multimap.impl.MultiMapMergeContainer
 
getCreationTime() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
getCreationTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
getCreationTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
getCreationTime() - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
getCreationTime() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
getCreationTime() - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
getCreationTime() - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
getCreationTime() - Method in interface com.hazelcast.spi.merge.MergingCreationTime
Returns the creation time of the merge data.
getCreationTime() - Method in interface com.hazelcast.wan.impl.InternalWanReplicationEvent
Returns the creation time for this event in milliseconds.
getCredentials() - Method in interface com.hazelcast.client.impl.ClientEndpoint
 
getCredentials() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
getCredentials() - Method in class com.hazelcast.config.security.CredentialsIdentityConfig
 
getCredentials() - Method in class com.hazelcast.internal.cluster.impl.JoinRequest
 
getCredentialsFactory() - Method in class com.hazelcast.client.impl.clientside.CandidateClusterContext
 
getCredentialsFactory() - Method in interface com.hazelcast.security.SecurityContext
Returns current ICredentialsFactory.
getCredentialsFactoryConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
getCredentialsFactoryConfig() - Method in class com.hazelcast.config.security.RealmConfig
 
getCredentialsIdentityConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
getCredentialsIdentityConfig() - Method in class com.hazelcast.config.security.RealmConfig
 
getCurrConnections() - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
getCurrent() - Method in class com.hazelcast.query.impl.getters.JsonPathCursor
Returns the current attribute path part.
getCurrentAsUTF8() - Method in class com.hazelcast.query.impl.getters.JsonPathCursor
Returns byte array of UTF8 encoded JsonPathCursor.getCurrent().
getCurrentClientConnections() - Method in class com.hazelcast.internal.jmx.NetworkingServiceMBean
 
getCurrentClusterHotRestartStatus() - Method in interface com.hazelcast.internal.hotrestart.InternalHotRestartService
Returns latest Hot Restart status as Management Center DTO.
getCurrentClusterHotRestartStatus() - Method in class com.hazelcast.internal.hotrestart.NoopInternalHotRestartService
 
getCurrentId() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
getCurrentId() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
 
getCurrentKeyAlias() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Returns the alias for the current encryption key entry or null if no alias is set.
getCurrentMembers() - Method in class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
Returns the snapshot of member list at the time split brain protection happened
getCurrentReplicaIndex() - Method in class com.hazelcast.spi.partition.PartitionMigrationEvent
Gets the index of the partition replica that current member owns currently, before migration starts.
getCurrentState() - Method in class com.hazelcast.client.util.ClientStateListener
 
getCurrentTargetReplicaAddress() - Method in class com.hazelcast.client.impl.proxy.ClientPNCounterProxy
Returns the current target replica address to which this proxy is sending invocations.
getCurrentTargetReplicaAddress() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterProxy
Returns the current target replica address to which this proxy is sending invocations.
getCurrentValue() - Method in class com.hazelcast.internal.jmx.AtomicLongMBean
 
getCurrentVectorClock() - Method in interface com.hazelcast.internal.crdt.CRDT
Returns the current vector clock which reflects the current CRDT state.
getCurrentVectorClock() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterImpl
 
getCustomPublisherConfigs() - Method in class com.hazelcast.config.WanReplicationConfig
Returns the list of custom WAN publisher implementations for this WAN replication.
getData() - Method in class com.hazelcast.collection.impl.collection.CollectionEvent
 
getData() - Method in class com.hazelcast.collection.impl.queue.QueueItem
 
getData() - Method in class com.hazelcast.internal.ascii.rest.HttpPostCommand
 
getDataEntrySet() - Method in class com.hazelcast.multimap.impl.operations.EntrySetResponse
 
getDataFromMap(long) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
 
getDataItems() - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
 
getDataItems() - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
 
getDataKey() - Method in class com.hazelcast.cache.impl.CacheEventContext
 
getDataKey() - Method in interface com.hazelcast.cache.impl.CacheEventData
Gets cache entry key as Data.
getDataKey() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
 
getDataKey() - Method in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
 
getDataKey() - Method in class com.hazelcast.map.impl.event.EntryEventData
 
getDataKey() - Method in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
 
getDataKey() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
getDataKey() - Method in interface com.hazelcast.map.impl.querycache.event.QueryCacheEventData
 
getDataLoadTimeoutSeconds() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the timeout duration for CP members to restore their data from stable storage.
getDataLoadTimeoutSeconds() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Returns configured data load timeout for hot-restart process.
getDataMemberCount() - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
 
getDataMembers() - Method in class com.hazelcast.client.cache.impl.nearcache.invalidation.ClientCacheInvalidationMetaDataFetcher
 
getDataMembers() - Method in class com.hazelcast.client.map.impl.nearcache.invalidation.ClientMapInvalidationMetaDataFetcher
 
getDataMembers() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationMetaDataFetcher
 
getDataMembers() - Method in class com.hazelcast.map.impl.nearcache.invalidation.MemberMapInvalidationMetaDataFetcher
 
getDataMergingValue() - Method in class com.hazelcast.map.impl.event.EntryEventData
 
getDataNewValue() - Method in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
 
getDataNewValue() - Method in class com.hazelcast.map.impl.event.EntryEventData
 
getDataNewValue() - Method in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
 
getDataNewValue() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
getDataNewValue() - Method in interface com.hazelcast.map.impl.querycache.event.QueryCacheEventData
 
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.cache.impl.journal.InternalEventJournalCacheEvent
 
getDataOldValue() - Method in class com.hazelcast.map.impl.event.EntryEventData
 
getDataOldValue() - Method in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
 
getDataOldValue() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
getDataOldValue() - Method in interface com.hazelcast.map.impl.querycache.event.QueryCacheEventData
 
getDataRecoveryPolicy() - Method in class com.hazelcast.internal.management.dto.ClusterHotRestartStatusDTO
 
getDataSerializableFactories() - Method in class com.hazelcast.config.SerializationConfig
 
getDataSerializableFactories() - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1.AbstractBuilder
 
getDataSerializableFactoryClasses() - Method in class com.hazelcast.config.SerializationConfig
 
getDataStructureName(Store) - Method in class com.hazelcast.spi.impl.merge.AbstractMergeRunnable
 
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
 
getDecoder() - Method in class com.hazelcast.internal.ascii.AbstractTextCommand
 
getDecoder() - Method in interface com.hazelcast.internal.ascii.TextCommand
 
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.
getDefaultClassLoader() - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
getDefaultClassLoader() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
 
getDefaultGlobalMemoryAccessor() - Static method in class com.hazelcast.internal.memory.GlobalMemoryAccessorRegistry
Returns the default GlobalMemoryAccessor instance.
getDefaultHazelcastInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Gets the default HazelcastOSGiInstance.
getDefaultMapServiceConstructor() - Static method in class com.hazelcast.map.impl.MapServiceConstructor
Returns a Constructor which will be used to create a MapService object.
getDefaultProperties() - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
getDefaultProperties() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
 
getDefaultReadTimeout() - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
Return default cache value retrieval timeout in milliseconds.
getDefaultURI() - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
getDefaultURI() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
 
getDefaultValue() - Method in class com.hazelcast.spi.properties.HazelcastProperty
Returns the default value of the property.
getDefinition() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskDescriptor
 
getDelay(TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledFutureProxy
 
getDelay(TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.DelegatingScheduledFutureStripper
 
getDelay(String, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
getDelay(TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledFutureProxy
 
GetDelayOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
GetDelayOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetDelayOperation
 
GetDelayOperation(ScheduledTaskHandler, TimeUnit) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetDelayOperation
 
getDelaySeconds() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
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
getDelaySeconds() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
 
getDelegate() - Method in interface com.hazelcast.map.impl.querycache.subscriber.InternalQueryCache
 
getDelegate() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
getDelegate() - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
getDelegatedInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiInstance
Gets the delegated (underlying) HazelcastInstance.
getDeleteHits() - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
getDeleteMisses() - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
getDeprecatedName() - Method in class com.hazelcast.spi.properties.HazelcastProperty
 
getDepth() - Method in class com.hazelcast.config.MerkleTreeConfig
Returns the depth of the merkle tree.
getDescriptor() - Method in enum com.hazelcast.instance.ProtocolType
 
getDeserializedKey() - Method in class com.hazelcast.spi.impl.merge.AbstractMergingEntryImpl
 
getDeserializedKey() - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
getDeserializedKey() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
getDeserializedKey() - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
getDeserializedKey() - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
getDeserializedKey() - Method in interface com.hazelcast.spi.merge.MergingEntry
Returns the deserialized merging key.
getDeserializedValue() - Method in class com.hazelcast.spi.impl.merge.AbstractCollectionMergingValueImpl
 
getDeserializedValue() - Method in class com.hazelcast.spi.impl.merge.AbstractMergingEntryImpl
 
getDeserializedValue() - Method in class com.hazelcast.spi.impl.merge.AbstractMergingValueImpl
 
getDeserializedValue() - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
getDeserializedValue() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
getDeserializedValue() - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
getDeserializedValue() - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
getDeserializedValue() - Method in class com.hazelcast.spi.impl.merge.RingbufferMergingValueImpl
 
getDeserializedValue() - Method in interface com.hazelcast.spi.merge.MergingValue
Returns the deserialized merging value.
getDestination() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
getDestination() - Method in class com.hazelcast.internal.partition.ReplicaMigrationEventImpl
 
getDestination() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
Returns the new owner of the migrating partition replica.
getDestinationAddress() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
getDestinationCurrentReplicaIndex() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
getDestinationNewReplicaIndex() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
getDestroyed() - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueSnapshot
 
getDestroyingGroupIds() - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
GetDestroyingRaftGroupIdsOp - Class in com.hazelcast.cp.internal.raftop.metadata
Returns ids of the Raft groups that are currently being destroyed.
GetDestroyingRaftGroupIdsOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.GetDestroyingRaftGroupIdsOp
 
getDiagnostics() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getDiffPercentage() - Method in class com.hazelcast.wan.ConsistencyCheckResult
 
getDir() - Method in class com.hazelcast.internal.util.DirectoryLock
Returns the locked directory.
getDirectory() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
getDirtyEntryCount() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
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).
getDiscoveredCPMembers() - Method in class com.hazelcast.cp.internal.raftop.metadata.InitMetadataRaftGroupOp
 
getDiscoveryConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the configuration of the Hazelcast Discovery SPI and configured discovery providers
getDiscoveryConfig() - Method in class com.hazelcast.config.JoinConfig
Returns the currently defined DiscoveryConfig
getDiscoveryConfig() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the currently defined DiscoveryConfig used by the discovery mechanism for this WAN publisher.
getDiscoveryConfig() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
getDiscoveryMode() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
getDiscoveryNode() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
getDiscoveryPeriodSeconds() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the period in seconds in which WAN tries to discover new target endpoints and reestablish connections to failed endpoints.
getDiscoveryService() - Method in class com.hazelcast.instance.impl.Node
 
getDiscoveryServiceProvider() - Method in class com.hazelcast.config.DiscoveryConfig
 
getDiscoveryStrategies() - Method in class com.hazelcast.spi.discovery.impl.DefaultDiscoveryService
 
getDiscoveryStrategyConfigs() - Method in class com.hazelcast.config.DiscoveryConfig
Returns the defined DiscoveryStrategy configurations.
getDiscoveryStrategyFactory() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
getDiscoveryStrategyType() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategyFactory
Returns the type of the DiscoveryStrategy itself.
getDiscoveryStrategyType() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategyFactory
 
getDiscoveryToken() - Method in class com.hazelcast.client.config.ClientCloudConfig
hazelcast.cloud discoveryToken of your cluster
getDistributedObject(String, String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getDistributedObject(String, String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getDistributedObject() - Method in class com.hazelcast.client.impl.spi.impl.listener.LazyDistributedObjectEvent
 
getDistributedObject() - Method in class com.hazelcast.core.DistributedObjectEvent
Returns the DistributedObject instance.
getDistributedObject(String, String) - Method in interface com.hazelcast.core.HazelcastInstance
 
getDistributedObject(String, String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getDistributedObject(String, String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getDistributedObject(String, String) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
 
getDistributedObject(String, String) - Method in interface com.hazelcast.spi.impl.proxyservice.ProxyService
 
getDistributedObjectName(String) - Static method in class com.hazelcast.cache.CacheUtil
Convenience method to obtain the name of Hazelcast distributed object corresponding to the cache identified by the given cacheName, assuming null URI and ClassLoader prefixes.
getDistributedObjectName(String, URI, ClassLoader) - Static method in class com.hazelcast.cache.CacheUtil
Convenience method to obtain the name of Hazelcast distributed object corresponding to the cache identified by the given arguments.
getDistributedObjectName() - Method in class com.hazelcast.cache.impl.tenantcontrol.CacheDestroyEventContext
 
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.AddBackupListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
 
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.CacheAddNearCacheInvalidationListenerTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsMessageTask
 
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.CacheEventJournalReadTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalSubscribeTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheFetchNearCacheInvalidationMetadataTask
 
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.CacheIterateEntriesMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutAllMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutIfAbsentMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheReplaceMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSetExpiryPolicyMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSizeMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.Pre38CacheAddInvalidationListenerTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorAddMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorEstimateMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ClientStatisticsMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterAddMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetConfiguredReplicaCountMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxiesMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.DeployClassesMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AbstractAddConfigMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorDisposeResultMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorIsShutdownMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveAndDisposeResultMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveResultMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorShutdownMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorSubmitToPartitionMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnAddressMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnPartitionMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.IsFailoverSupportedMessageTask
 
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.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.MapAddListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddNearCacheInvalidationListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateWithPredicateMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsMessageTask
 
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.MapDestroyCacheMessageTask
 
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.MapEventJournalReadTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEventJournalSubscribeTask
 
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.MapFetchEntriesMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchKeysMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchNearCacheInvalidationMetadataTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchWithQueryMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetEntryViewMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapMadePublishableMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionWithPredicateMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateWithValueMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentWithMaxIdleMessageTask
 
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.MapPutTransientWithMaxIdleMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutWithMaxIdleMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveAllMessageTask
 
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.MapSetReadCursorMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetTtlMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetWithMaxIdleMessageTask
 
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.map.Pre38MapAddNearCacheEntryListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.metrics.ReadMetricsMessageTask
 
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.MultiMapDeleteMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapGetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapPutMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValueCountMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddAllMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueClearMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRemoveAllMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRetainAllMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsAllMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMaxSizeMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIsEmptyMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIteratorMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueOfferMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePeekMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePollMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePutMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemainingCapacityMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueSizeMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueTakeMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddAllMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferCapacityMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferHeadSequenceMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadManyMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadOneMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferRemainingCapacityMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferSizeMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferTailSequenceMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorGetAllScheduledMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorShutdownMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToAddressMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToPartitionMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromAddressMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromPartitionMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromAddressMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromPartitionMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromAddressMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromPartitionMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromAddressMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromPartitionMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromAddressMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromPartitionMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromAddressMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromPartitionMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromAddressMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromPartitionMessageTask
 
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.client.impl.spi.ClientProxy
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.AddAndGetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.AlterMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.ApplyMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.CompareAndSetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetAndAddMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetAndSetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.ApplyMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.CompareAndSetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.ContainsMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.GetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.SetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.AwaitMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.CountDownMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.GetCountMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.GetRoundMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.TrySetCountMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.GetLockOwnershipStateMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.LockMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.TryLockMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.UnlockMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.AcquirePermitsMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.AvailablePermitsMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.ChangePermitsMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.DrainPermitsMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.GetSemaphoreTypeMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.InitSemaphoreMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.ReleasePermitsMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.spi.client.CreateRaftGroupMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.cp.internal.datastructures.spi.client.DestroyRaftObjectMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.flakeidgen.impl.client.NewIdBatchMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterAddAndGetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterDecrementAndGetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndAddMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndIncrementMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndSetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterIncrementAndGetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterSetMessageTask
 
getDistributedObjectName() - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
getDistributedObjectName() - Method in interface com.hazelcast.spi.tenantcontrol.DestroyEventContext
 
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.impl.proxyservice.ProxyService
 
getDistributedObjects() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getDistributedObjects() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getDistributedObjects() - Method in class com.hazelcast.client.impl.spi.ProxyManager
 
getDistributedObjects() - Method in interface com.hazelcast.core.HazelcastInstance
Returns all DistributedObjects, that is all maps, queues, topics, locks etc.
getDistributedObjects() - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getDistributedObjects() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
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.impl.proxyservice.ProxyService
 
GetDistributedObjectsMessageTask - Class in com.hazelcast.client.impl.protocol.task
 
GetDistributedObjectsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
 
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
 
getDouble(String, double) - Method in class com.hazelcast.internal.json.JsonObject
Returns the double value of the member with the specified name in this object.
getDouble(Object, long) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Returns the double value at the supplied offset from the supplied object's base address.
getDouble(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getDouble(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getDouble(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getDouble(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getDouble(long) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Reads the double value from given address.
getDouble(JsonObject, String) - Static method in class com.hazelcast.internal.util.JsonUtil
Returns a field in a Json object as a double.
getDouble(JsonObject, String, double) - Static method in class com.hazelcast.internal.util.JsonUtil
Returns a field in a Json object as a double.
getDouble(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured double value of a HazelcastProperty.
getDoubleValue(String, String) - Static method in class com.hazelcast.config.DomConfigHelper
 
getDoubleValue(String, String, double) - Static method in class com.hazelcast.config.DomConfigHelper
 
getDoubleVolatile(Object, long) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Reads the double value as volatile from given object by its offset.
getDoubleVolatile(long) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Reads the double value as volatile from given object by its offset.
getDoubleVolatile(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getDoubleVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getDoubleVolatile(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getDoubleVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getDroppedCount() - Method in class com.hazelcast.wan.DistributedServiceWanEventCounters.DistributedObjectWanEventCounters
Returns the number of dropped entry events
getDurability() - Method in class com.hazelcast.config.DurableExecutorConfig
Gets the durability of the executor
getDurability() - Method in class com.hazelcast.config.ScheduledExecutorConfig
Gets the durability of the executor
getDurability() - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorContainer
 
getDurability() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
getDurability() - Method in class com.hazelcast.transaction.TransactionOptions
Gets the transaction durability.
getDurable(String) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
getDurable(String) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
getDurableExecutorConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getDurableExecutorConfig(String) - Method in class com.hazelcast.config.Config
Returns the DurableExecutorConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getDurableExecutorConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getDurableExecutorConfigs() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getDurableExecutorConfigs() - Method in class com.hazelcast.config.Config
Returns the map of durable executor configurations, mapped by config name.
getDurableExecutorConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
getDurableExecutorConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Returns all registered durable executor configurations.
getDurableExecutorConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getDurableExecutorService(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getDurableExecutorService(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getDurableExecutorService(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the durable executor service for the given name.
getDurableExecutorService(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getDurableExecutorService(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getDurationAmount() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
getDurationConfig() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
getDurationSecs() - Method in interface com.hazelcast.wan.WanSyncStats
Returns the duration of the synchronization in seconds.
getDynamicConfig(ConfigurationService, String) - Method in interface com.hazelcast.internal.dynamicconfig.search.ConfigSupplier
Get dynamic configuration for the given name
getElapsedDestinationCommitTime() - Method in class com.hazelcast.internal.partition.impl.MigrationStats
Returns the total elapsed time of commit operations' executions to the destination endpoint, in milliseconds, on the latest repartitioning round.
getElapsedMigrationOperationTime() - Method in class com.hazelcast.internal.partition.impl.MigrationStats
Returns the total elapsed time of migration & replication operations' executions from source to destination endpoints, in milliseconds, on the latest repartitioning round.
getElapsedMigrationTime() - Method in class com.hazelcast.internal.partition.impl.MigrationStats
Returns the total elapsed time from start of migration tasks to their completion, in milliseconds, on the latest repartitioning round.
getElapsedTime() - Method in class com.hazelcast.internal.partition.ReplicaMigrationEventImpl
 
getElapsedTime() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
Returns the elapsed the time of this migration in milliseconds.
getElementsByTagName(String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getElementsByTagNameNS(String, String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getEmpty() - Method in class com.hazelcast.internal.jmx.suppliers.LocalMapStatsSupplier
 
getEmpty() - Method in class com.hazelcast.internal.jmx.suppliers.LocalMultiMapStatsSupplier
 
getEmpty() - Method in class com.hazelcast.internal.jmx.suppliers.LocalQueueStatsSupplier
 
getEmpty() - Method in class com.hazelcast.internal.jmx.suppliers.LocalReplicatedMapStatsSupplier
 
getEmpty() - Method in interface com.hazelcast.internal.jmx.suppliers.StatsSupplier
 
getEmptyPollOperationCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
getEmptyPollOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns number of null returning poll operations.
getEmptyQueueTtl() - Method in class com.hazelcast.config.QueueConfig
Returns the TTL (time to live) for emptying the Queue.
getEnabledGroups() - Method in class com.hazelcast.config.RestApiConfig
Returns a not-null set of enabled REST endpoint groups.
getEnabledGroups() - Method in class com.hazelcast.config.RestServerEndpointConfig
Returns a not-null set of enabled REST endpoint groups.
getEncoder() - Method in class com.hazelcast.internal.ascii.AbstractTextCommand
 
getEncoder() - Method in interface com.hazelcast.internal.ascii.TextCommand
 
getEncoder() - Method in class com.hazelcast.internal.nio.ascii.TextDecoder
 
getEncoding() - Method in class com.hazelcast.config.security.TokenIdentityConfig
 
getEncodingForBytes(byte[]) - Static method in enum com.hazelcast.config.security.TokenEncoding
 
getEncodingType() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.DenseHyperLogLogEncoder
 
getEncodingType() - Method in interface com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogEncoder
Returns the encoding type of this instance; see: HyperLogLogEncoding
getEncodingType() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.SparseHyperLogLogEncoder
 
getEncryptionAtRestConfig() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Returns the Hot Restart Encryption at Rest configuration.
getEndpoint(Connection) - Method in interface com.hazelcast.client.impl.ClientEndpointManager
Gets the endpoint for a given connection.
getEndpoint(Connection) - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
 
getEndPoint() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
getEndpoint() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the WAN endpoint configuration qualifier.
getEndPoint() - Method in interface com.hazelcast.internal.nio.Connection
Gets the Address of the other side of this Connection.
getEndPoint() - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
getEndPoint() - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnectionErrorHandler
 
getEndpointConfigs() - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
getEndpointManager() - Method in interface com.hazelcast.client.impl.ClientEngine
 
getEndpointManager() - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
getEndpointManager() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
getEndpointManager() - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
getEndpointManager() - Method in class com.hazelcast.instance.impl.Node
 
getEndpointManager(EndpointQualifier) - Method in class com.hazelcast.instance.impl.Node
 
getEndpointManager() - Method in interface com.hazelcast.internal.nio.Connection
 
getEndpointManager(EndpointQualifier) - Method in class com.hazelcast.internal.nio.DefaultAggregateEndpointManager
 
getEndpointManager(EndpointQualifier) - Method in interface com.hazelcast.internal.nio.NetworkingService
Returns the relevant EndpointManager given an EndpointQualifier On single-endpoint setups (legacy mode), then a View relevant to the requested Endpoint is returned which purely acts as a facade to hide the API differences and maintain common signatures.
getEndpointManager() - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
getEndpointManager(EndpointQualifier) - Method in class com.hazelcast.internal.nio.tcp.TcpIpNetworkingService
Returns the respective endpoint manager based on the qualifier.
getEndpointManager(EndpointQualifier) - Method in class com.hazelcast.internal.nio.UnifiedAggregateEndpointManager
 
getEndpointQualifier() - Method in class com.hazelcast.internal.nio.tcp.TcpIpEndpointManager
 
getEndpoints() - Method in interface com.hazelcast.client.impl.ClientEndpointManager
Returns the current endpoints.
getEndpoints() - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
 
getEndpoints() - Method in class com.hazelcast.config.PermissionConfig
 
getEndpoints() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
getEndToEndQueryCacheProvider() - Method in class com.hazelcast.map.impl.querycache.subscriber.AbstractSubscriberContext
 
getEndToEndQueryCacheProvider() - Method in interface com.hazelcast.map.impl.querycache.subscriber.SubscriberContext
Returns QueryCacheEndToEndProvider for this context.
getEngineByExtension(String) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
 
getEngineByMimeType(String) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
 
getEngineByName(String) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
 
getEngineFactories() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
 
getEngineName() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
 
getEngineVersion() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
 
getEntries() - Method in class com.hazelcast.cache.impl.CacheEntryIterationResult
 
getEntries() - Method in class com.hazelcast.query.impl.QueryableEntriesSegment
 
getEntriesBetween(long, long) - Method in class com.hazelcast.cp.internal.raft.impl.log.RaftLog
Returns log entries between fromEntryIndex and toEntryIndex, both inclusive.
getEntryCostEstimator() - Method in interface com.hazelcast.map.impl.recordstore.Storage
 
getEntryCostEstimator() - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
getEntryCount() - Method in class com.hazelcast.cache.impl.CacheContext
 
getEntryCount() - Method in class com.hazelcast.cache.impl.CacheEntryCountResolver
 
getEntryCountDelta() - Method in class com.hazelcast.monitor.impl.GlobalIndexOperationStats
 
getEntryCountDelta() - Method in interface com.hazelcast.monitor.impl.IndexOperationStats
Returns the indexed entry count delta produced as a result of an index operation.
getEntryCountDelta() - Method in class com.hazelcast.monitor.impl.PartitionIndexOperationStats
 
getEntryEventDataCache() - Method in class com.hazelcast.map.impl.event.DefaultEntryEventFilteringStrategy
 
getEntryEventDataCache() - Method in interface com.hazelcast.map.impl.event.FilteringStrategy
 
getEntryEventDataCache() - Method in class com.hazelcast.map.impl.event.QueryCacheNaturalFilteringStrategy
 
getEntryKey() - Method in class com.hazelcast.internal.util.SampleableConcurrentHashMap.SamplingEntry
 
getEntryListenerConfigs() - Method in class com.hazelcast.config.MapConfig
 
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.QueryCacheConfig
 
getEntryListenerConfigs() - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
getEntryListenerConfigs() - Method in class com.hazelcast.internal.config.MultiMapConfigReadOnly
 
getEntryListenerConfigs() - Method in class com.hazelcast.internal.config.QueryCacheConfigReadOnly
 
getEntryObject() - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
getEntryObject() - Method in interface com.hazelcast.query.PredicateBuilder
 
getEntryValue() - Method in class com.hazelcast.internal.util.SampleableConcurrentHashMap.SamplingEntry
 
getEntryView(K) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
getEntryView(K) - Method in interface com.hazelcast.map.IMap
Returns the EntryView for the specified key.
getEntryView(K) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
getEntryView() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
 
GetEntryViewOperation - Class in com.hazelcast.map.impl.operation
 
GetEntryViewOperation() - Constructor for class com.hazelcast.map.impl.operation.GetEntryViewOperation
 
GetEntryViewOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.GetEntryViewOperation
 
getEnum(HazelcastProperty, Class<E>) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured enum value of a GroupProperty.
getErrorCode() - Method in class com.hazelcast.client.impl.protocol.exception.ErrorHolder
 
getEstimate() - Method in interface com.hazelcast.map.impl.EntryCostEstimator
Returns the memory cost estimation so far
getEurekaConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the current EurekaConfig.
getEurekaConfig() - Method in class com.hazelcast.config.JoinConfig
 
getEurekaConfig() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the EurekaConfig used by the discovery mechanism for this WAN publisher.
getEvent() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventEnvelope
 
getEvent() - Method in class com.hazelcast.spi.impl.eventservice.impl.LocalEventDispatcher
 
getEventCount() - Method in class com.hazelcast.internal.networking.nio.NioThread
Returns the total number of selection-key events that have been processed by this thread.
getEventCounterMap() - Method in class com.hazelcast.wan.DistributedServiceWanEventCounters
Returns a map from distributed object name to DistributedServiceWanEventCounters.DistributedObjectWanEventCounters.
getEventData() - Method in class com.hazelcast.map.impl.querycache.event.SingleIMapEvent
 
getEventExecutor() - Method in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
getEventExecutor() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
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.MapAddNearCacheInvalidationListenerMessageTask
 
getEventFilter() - Method in class com.hazelcast.client.impl.protocol.task.map.Pre38MapAddNearCacheEntryListenerMessageTask
 
getEventFilter() - Method in class com.hazelcast.map.impl.EventListenerFilter
 
getEventFilter() - Method in class com.hazelcast.map.impl.querycache.publisher.PartitionAccumulatorRegistry
 
getEventHandlers() - Method in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
getEventId() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventEnvelope
The event ID.
getEventJournal() - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
getEventJournal() - Method in interface com.hazelcast.cache.impl.ICacheService
Returns an interface for interacting with the cache event journals.
getEventJournal() - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getEventJournalConfig(ObjectNamespace) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
Returns the event journal configuration or null if there is none or the journal is disabled for the given namespace.
getEventJournalConfig() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
getEventJournalConfig() - Method in class com.hazelcast.config.AbstractCacheConfig
Gets the EventJournalConfig for this CacheConfiguration
getEventJournalConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the EventJournalConfig for this CacheSimpleConfig
getEventJournalConfig() - Method in class com.hazelcast.config.MapConfig
Gets the EventJournalConfig for this MapConfig
getEventJournalConfig() - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
getEventJournalConfig() - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
getEventJournalConfig(ObjectNamespace) - Method in interface com.hazelcast.internal.journal.EventJournal
Returns the event journal configuration or null if there is none or the journal is disabled for the given namespace.
getEventJournalConfig(ObjectNamespace) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
 
getEventJournalConfig() - Method in class com.hazelcast.map.impl.MapContainer
 
getEventOperationCount() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
getEventOperationCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
getEventOperationCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
getEventOperationCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
getEventOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of Events Received
getEventOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns number of event operations
getEventPublishingService() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
getEventQueueCapacity() - Method in class com.hazelcast.internal.jmx.EventServiceMBean
 
getEventQueueCapacity() - Method in interface com.hazelcast.spi.impl.eventservice.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.internal.jmx.EventServiceMBean
 
getEventQueueSize() - Method in interface com.hazelcast.spi.impl.eventservice.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.map.impl.querycache.event.BatchEventData
 
getEventService() - Method in interface com.hazelcast.client.impl.ClientEngine
 
getEventService() - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
getEventService() - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
getEventService() - Method in interface com.hazelcast.internal.nio.IOService
 
getEventService() - Method in class com.hazelcast.internal.nio.NodeIOService
 
getEventService() - Method in class com.hazelcast.map.impl.querycache.subscriber.AbstractSubscriberContext
 
getEventService() - Method in interface com.hazelcast.map.impl.querycache.subscriber.SubscriberContext
Returns QueryCacheEventService for this context.
getEventService() - Method in interface com.hazelcast.spi.impl.NodeEngine
Gets the EventService.
getEventService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getEventServiceBean() - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
 
getEventServiceMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getEventSource() - Method in class com.hazelcast.internal.partition.PartitionLostEventImpl
Returns the address of the node that dispatches the event
getEventSource() - Method in interface com.hazelcast.partition.PartitionLostEvent
Returns the address of the node that dispatches the event
getEventSource() - Method in interface com.hazelcast.spi.partition.IPartitionLostEvent
The address of the node that detects the partition lost.
getEventThreadCount() - Method in class com.hazelcast.internal.jmx.EventServiceMBean
 
getEventThreadCount() - Method in interface com.hazelcast.spi.impl.eventservice.EventService
Returns the event thread count.
getEventThreadCount() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
getEventType() - Method in class com.hazelcast.cache.impl.CacheEventContext
 
getEventType() - Method in class com.hazelcast.cache.impl.CacheEventSet
 
getEventType() - Method in class com.hazelcast.cache.impl.event.AbstractICacheEvent
Returns the event type EntryEventType.
getEventType() - Method in interface com.hazelcast.cache.impl.event.ICacheEvent
Return the event type
getEventType() - Method in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
Return the integer defining the event type.
getEventType() - Method in class com.hazelcast.client.impl.ClientEvent
 
getEventType() - Method in class com.hazelcast.cluster.MembershipEvent
Returns the membership event type; #MEMBER_ADDED #MEMBER_REMOVED #MEMBER_ATTRIBUTE_CHANGED
getEventType() - Method in class com.hazelcast.collection.impl.collection.CollectionEvent
 
getEventType() - Method in class com.hazelcast.collection.impl.queue.QueueEvent
 
getEventType() - Method in class com.hazelcast.collection.ItemEvent
Returns the event type.
getEventType() - Method in class com.hazelcast.core.DistributedObjectEvent
getEventType() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidation
 
getEventType() - Method in class com.hazelcast.map.AbstractIMapEvent
Returns the event type EntryEventType.
getEventType() - Method in class com.hazelcast.map.EventLostEvent
Intentionally returns null.
getEventType() - Method in interface com.hazelcast.map.IMapEvent
Return the event type
getEventType() - Method in interface com.hazelcast.map.impl.event.EventData
 
getEventType() - Method in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
Return the integer defining the event type.
getEventType() - Method in class com.hazelcast.map.impl.operation.EntryOperator
 
getEventType() - Method in class com.hazelcast.map.impl.operation.WanEventHolder
 
getEventType() - Method in class com.hazelcast.map.impl.querycache.event.BatchEventData
 
getEventType() - Method in class com.hazelcast.map.impl.querycache.event.BatchIMapEvent
 
getEventType() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
getEventType() - Method in class com.hazelcast.map.impl.querycache.event.LocalCacheWideEventData
 
getEventType() - Method in class com.hazelcast.map.impl.querycache.event.LocalEntryEventData
 
getEventType() - Method in class com.hazelcast.map.impl.querycache.event.SingleIMapEvent
 
getEventType() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
 
getEventType() - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
 
getEventType() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
 
getEventType() - Method in class com.hazelcast.spi.impl.PortableItemEvent
 
getEventType() - Method in class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectEventPacket
 
getEvictable() - Method in interface com.hazelcast.internal.eviction.EvictionCandidate
The value of Evictable entry or record or whatever.
getEvictable() - Method in class com.hazelcast.internal.nearcache.impl.store.HeapNearCacheRecordMap.NearCacheEvictableSamplingEntry
 
getEvictionConfig() - Method in class com.hazelcast.config.CacheConfig
Gets the EvictionConfig instance of the eviction configuration for this ICache.
getEvictionConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the eviction configuration for this ICache.
getEvictionConfig() - Method in class com.hazelcast.config.NearCacheConfig
Returns the eviction configuration for this Near Cache.
getEvictionConfig() - Method in class com.hazelcast.config.QueryCacheConfig
Returns EvictionConfig instance for this QueryCache
getEvictionConfig() - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
getEvictionConfig() - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
getEvictionConfig() - Method in class com.hazelcast.internal.config.NearCacheConfigReadOnly
 
getEvictionConfig() - Method in class com.hazelcast.internal.config.QueryCacheConfigReadOnly
 
getEvictionConfig(Node, boolean) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
getEvictionConfigHolder() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
getEvictionConfigHolder() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.NearCacheConfigHolder
 
getEvictionConfigHolder() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
getEvictionCriteriaNumber() - Method in class com.hazelcast.map.impl.SimpleEntryView
Needed for client protocol compatibility.
getEvictionPolicy() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.EvictionConfigHolder
 
getEvictionPolicy() - Method in class com.hazelcast.config.EvictionConfig
Returns the EvictionPolicy of this eviction configuration.
getEvictionPolicy() - Method in class com.hazelcast.config.MapConfig
Returns the EvictionPolicy.
getEvictionPolicy() - Method in interface com.hazelcast.internal.eviction.EvictionConfiguration
Gets the eviction policy.
getEvictionPolicyComparator() - Method in class com.hazelcast.internal.eviction.impl.evaluator.EvictionPolicyEvaluator
 
getEvictionPolicyEvaluator(EvictionConfiguration, ClassLoader) - Static method in class com.hazelcast.internal.eviction.EvictionPolicyEvaluatorProvider
Gets the EvictionPolicyEvaluator implementation specified with evictionPolicy.
getEvictions() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
getEvictions() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the number of evictions of Near Cache entries owned by this member.
getEvictionStrategyType() - Method in class com.hazelcast.config.EvictionConfig
Returns the EvictionStrategyType of this eviction configuration.
getEvictionStrategyType() - Method in interface com.hazelcast.internal.eviction.EvictionConfiguration
Gets the type of eviction strategy.
getEvictor() - Method in class com.hazelcast.map.impl.MapContainer
 
getEx() - Method in interface com.hazelcast.internal.util.function.SupplierEx
Exception-declaring version of Supplier.get().
getException() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskResult
 
getExcludedMemberUuids() - Method in class com.hazelcast.internal.cluster.impl.JoinRequest
 
getExcludedMemberUuids() - Method in interface com.hazelcast.internal.hotrestart.InternalHotRestartService
Returns UUIDs of the members that have been excluded during the cluster start.
getExcludedMemberUuids() - Method in class com.hazelcast.internal.hotrestart.NoopInternalHotRestartService
 
getExecutedCount() - Method in class com.hazelcast.internal.jmx.ManagedExecutorServiceMBean
 
getExecutedOperationCount() - Method in class com.hazelcast.internal.jmx.OperationServiceMBean
 
getExecutedOperationCount() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
getExecutedOperationCount() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
Returns the number of executed operations.
getExecutedOperationCount() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
getExecutedOperationCount() - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Returns the number of executed operations.
getExecutionCallback() - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Gets the ExecutionCallback.
getExecutionService() - Method in class com.hazelcast.client.impl.spi.ClientContext
 
getExecutionService() - Method in interface com.hazelcast.spi.impl.NodeEngine
Gets the ExecutionService.
getExecutionService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getExecutor() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Gets the Executor that is going to process the events.
getExecutor() - Method in class com.hazelcast.config.ReliableTopicConfig
Gets the Executor that is going to process the events.
getExecutor(String) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
getExecutor(String) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
getExecutorConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getExecutorConfig(String) - Method in class com.hazelcast.config.Config
Returns the ExecutorConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getExecutorConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getExecutorConfigs() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getExecutorConfigs() - Method in class com.hazelcast.config.Config
Returns the map of executor configurations, mapped by config name.
getExecutorConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
getExecutorConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Returns all registered executor configurations.
getExecutorConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getExecutorName() - Method in interface com.hazelcast.core.Offloadable
Returns the name of the executor to which the processing unit will be off-loaded.
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.clientside.HazelcastClientInstanceImpl
 
getExecutorService(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getExecutorService(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed executor service for the given name.
getExecutorService(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getExecutorService(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
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 class com.hazelcast.cache.impl.AbstractCacheService
 
getExpirationManager() - Method in interface com.hazelcast.cache.impl.ICacheService
 
getExpirationManager() - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getExpirations() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
getExpirations() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the number of TTL and max-idle expirations of Near Cache entries owned by this member.
getExpirationTime() - Method in interface com.hazelcast.cache.CacheEntryView
Gets the expiration time in milliseconds of the cache entry.
getExpirationTime() - Method in class com.hazelcast.cache.impl.CacheEventContext
 
getExpirationTime() - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
 
getExpirationTime() - Method in class com.hazelcast.cache.impl.merge.entry.LazyCacheEntryView
 
getExpirationTime() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
getExpirationTime() - Method in interface com.hazelcast.core.EntryView
Returns the expiration time of the entry.
getExpirationTime() - Method in interface com.hazelcast.internal.eviction.Expirable
Gets the expiration time in milliseconds.
getExpirationTime() - Method in interface com.hazelcast.internal.locksupport.LockResource
 
getExpirationTime() - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.CacheBrowserEntryView
 
getExpirationTime() - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
getExpirationTime() - Method in class com.hazelcast.map.EntryLoader.MetadataAwareValue
The expiration date of this entry.
getExpirationTime() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntry
 
getExpirationTime() - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
getExpirationTime() - Method in interface com.hazelcast.map.impl.record.Record
 
getExpirationTime() - Method in class com.hazelcast.map.impl.record.RecordInfo
 
getExpirationTime() - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
 
getExpirationTime() - Method in class com.hazelcast.map.impl.SimpleEntryView
 
getExpirationTime() - Method in class com.hazelcast.map.impl.wan.WanMapEntryView
 
getExpirationTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
getExpirationTime() - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
getExpirationTime() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
getExpirationTime() - Method in interface com.hazelcast.spi.merge.MergingExpirationTime
Returns the expiration time of the merge data.
getExpiredKeysQueue() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
getExpiredKeysQueue() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
 
getExpiredKeysQueue() - Method in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
getExpiredKeysQueue() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
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() - Method in interface com.hazelcast.cache.CacheEntryView
Gets the expiry policy associated with this entry if there is one.
getExpiryPolicy(CacheRecord, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
getExpiryPolicy(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
getExpiryPolicy() - Method in class com.hazelcast.cache.impl.CacheEventContext
 
getExpiryPolicy(Data) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
 
getExpiryPolicy() - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
Gets the expiry policy associated with this entry if any
getExpiryPolicy() - Method in class com.hazelcast.cache.impl.merge.entry.LazyCacheEntryView
 
getExpiryPolicy() - Method in class com.hazelcast.cache.impl.record.CacheDataRecord
 
getExpiryPolicy() - Method in class com.hazelcast.cache.impl.record.CacheObjectRecord
 
getExpiryPolicy() - Method in interface com.hazelcast.cache.impl.record.CacheRecord
Gets the expiryPolicy associated with this record.
getExpiryPolicy() - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.CacheBrowserEntryView
 
getExpiryPolicyFactory() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
getExpiryPolicyFactory() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getExpiryPolicyFactoryConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the factory configuration for the ExpiryPolicy.
getExpiryPolicyType() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
getExtensions() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
 
getExtractorClassName() - Method in class com.hazelcast.config.AttributeConfig
Gets the full class name of the extractor in a String format, e.g.
getExtractors() - Method in class com.hazelcast.map.impl.MapContainer
 
getExtractors(String) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getExtractors() - Method in interface com.hazelcast.map.impl.querycache.subscriber.InternalQueryCache
 
getExtractors() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
getFactories() - Method in class com.hazelcast.client.impl.protocol.DefaultMessageTaskFactoryProvider
 
getFactories() - Method in interface com.hazelcast.client.impl.protocol.MessageTaskFactoryProvider
 
getFactoryClassName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
getFactoryClassName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueueStoreConfigHolder
 
getFactoryClassName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.RingbufferStoreConfigHolder
 
getFactoryClassName() - Method in class com.hazelcast.config.MapStoreConfig
Returns the name of the MapStoreFactory implementation class
getFactoryClassName() - Method in class com.hazelcast.config.MCMutualAuthConfig
Returns the name of the implementation class.
getFactoryClassName() - Method in class com.hazelcast.config.QueueStoreConfig
 
getFactoryClassName() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getFactoryClassName() - Method in class com.hazelcast.config.SSLConfig
Returns the name of the implementation class.
getFactoryId() - Method in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.BigDecimalAverageAggregator
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.BigDecimalSumAggregator
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.BigIntegerAverageAggregator
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.BigIntegerSumAggregator
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.CountAggregator
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.DistinctValuesAggregator
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.DoubleAverageAggregator
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.DoubleSumAggregator
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.FixedSumAggregator
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.FloatingPointSumAggregator
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.IntegerAverageAggregator
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.IntegerSumAggregator
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.LongAverageAggregator
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.LongSumAggregator
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.MaxAggregator
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.MaxByAggregator
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.MinAggregator
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.MinByAggregator
 
getFactoryId() - Method in class com.hazelcast.aggregation.impl.NumberAverageAggregator
 
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.CacheEntryIterationResult
 
getFactoryId() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
 
getFactoryId() - Method in class com.hazelcast.cache.impl.CacheEventListenerAdaptor
 
getFactoryId() - Method in class com.hazelcast.cache.impl.CacheEventSet
 
getFactoryId() - Method in class com.hazelcast.cache.impl.CacheKeyIterationResult
 
getFactoryId() - Method in class com.hazelcast.cache.impl.event.CachePartitionLostEventFilter
 
getFactoryId() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalReadOperation
 
getFactoryId() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalReadResultSetImpl
 
getFactoryId() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalSubscribeOperation
 
getFactoryId() - Method in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
 
getFactoryId() - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
 
getFactoryId() - Method in class com.hazelcast.cache.impl.operation.AddCacheConfigOperation
 
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
Deprecated.
 
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.CacheGetConfigOperation
 
getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation
 
getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation.MetaDataResponse
 
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.CacheMergeOperationFactory
 
getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheNearCacheStateHolder
 
getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheOperation
 
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.CacheReplicationOperation
 
getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheSetExpiryPolicyBackupOperation
 
getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheSetExpiryPolicyOperation
 
getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
 
getFactoryId() - Method in class com.hazelcast.cache.impl.operation.OnJoinCacheOperation
 
getFactoryId() - Method in class com.hazelcast.cache.impl.PreJoinCacheConfig
 
getFactoryId() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
getFactoryId() - Method in class com.hazelcast.cache.impl.tenantcontrol.CacheDestroyEventContext
 
getFactoryId() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
 
getFactoryId() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.DenseHyperLogLogEncoder
 
getFactoryId() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogImpl
 
getFactoryId() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.SparseHyperLogLogEncoder
 
getFactoryId() - Method in class com.hazelcast.cardinality.impl.operations.AbstractCardinalityEstimatorOperation
 
getFactoryId() - Method in class com.hazelcast.cardinality.impl.operations.ReplicationOperation
 
getFactoryId() - Method in class com.hazelcast.client.impl.ClientDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.client.impl.operations.AbstractClientOperation
 
getFactoryId() - Method in class com.hazelcast.client.impl.operations.OperationFactoryWrapper
 
getFactoryId() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsOperation
 
getFactoryId() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsOperationFactory
 
getFactoryId() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsOperation
 
getFactoryId() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsOperationFactory
 
getFactoryId() - Method in class com.hazelcast.cluster.Address
 
getFactoryId() - Method in class com.hazelcast.cluster.impl.MemberImpl
 
getFactoryId() - Method in class com.hazelcast.cluster.impl.VectorClock
 
getFactoryId() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
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.operations.CollectionOperation
 
getFactoryId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionReplicationOperation
 
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.txncollection.CollectionTransactionLogRecord
 
getFactoryId() - Method in class com.hazelcast.config.AbstractBasicConfig
 
getFactoryId() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
getFactoryId() - Method in class com.hazelcast.config.AttributeConfig
 
getFactoryId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
getFactoryId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
getFactoryId() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
getFactoryId() - Method in class com.hazelcast.config.CacheSimpleConfig
 
getFactoryId() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
getFactoryId() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
getFactoryId() - Method in class com.hazelcast.config.CollectionConfig
 
getFactoryId() - Method in class com.hazelcast.config.ConfigDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.config.CustomWanPublisherConfig
 
getFactoryId() - Method in class com.hazelcast.config.DiscoveryConfig
 
getFactoryId() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
getFactoryId() - Method in class com.hazelcast.config.DurableExecutorConfig
 
getFactoryId() - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
getFactoryId() - Method in class com.hazelcast.config.EventJournalConfig
 
getFactoryId() - Method in class com.hazelcast.config.ExecutorConfig
 
getFactoryId() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getFactoryId() - Method in class com.hazelcast.config.HotRestartConfig
 
getFactoryId() - Method in class com.hazelcast.config.IndexConfig
 
getFactoryId() - Method in class com.hazelcast.config.ListenerConfig
 
getFactoryId() - Method in class com.hazelcast.config.MapConfig
 
getFactoryId() - Method in class com.hazelcast.config.MapStoreConfig
 
getFactoryId() - Method in class com.hazelcast.config.MergePolicyConfig
 
getFactoryId() - Method in class com.hazelcast.config.MerkleTreeConfig
 
getFactoryId() - Method in class com.hazelcast.config.MultiMapConfig
 
getFactoryId() - Method in class com.hazelcast.config.NearCacheConfig
 
getFactoryId() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
getFactoryId() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
getFactoryId() - Method in class com.hazelcast.config.PNCounterConfig
 
getFactoryId() - Method in class com.hazelcast.config.PredicateConfig
 
getFactoryId() - Method in class com.hazelcast.config.QueryCacheConfig
 
getFactoryId() - Method in class com.hazelcast.config.QueueConfig
 
getFactoryId() - Method in class com.hazelcast.config.QueueStoreConfig
 
getFactoryId() - Method in class com.hazelcast.config.ReliableTopicConfig
 
getFactoryId() - Method in class com.hazelcast.config.ReplicatedMapConfig
 
getFactoryId() - Method in class com.hazelcast.config.RingbufferConfig
 
getFactoryId() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getFactoryId() - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
getFactoryId() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
getFactoryId() - Method in class com.hazelcast.config.TopicConfig
 
getFactoryId() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
getFactoryId() - Method in class com.hazelcast.config.WanConsumerConfig
 
getFactoryId() - Method in class com.hazelcast.config.WanReplicationConfig
 
getFactoryId() - Method in class com.hazelcast.config.WanSyncConfig
 
getFactoryId() - Method in class com.hazelcast.cp.internal.CPGroupInfo
 
getFactoryId() - Method in class com.hazelcast.cp.internal.CPGroupSummary
 
getFactoryId() - Method in class com.hazelcast.cp.internal.CPMemberInfo
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongSnapshot
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.AbstractAtomicLongOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefSnapshot
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.AbstractAtomicRefOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.AwaitInvocationKey
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatch
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchRegistry
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.AbstractCountDownLatchOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.lock.Lock
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockEndpoint
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockInvocationKey
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockOwnershipState
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.GetLockOwnershipStateOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.RaftDataServiceDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.AcquireInvocationKey
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.AvailablePermitsOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.ChangePermitsOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.InitSemaphoreOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.Semaphore
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreEndpoint
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreRegistry
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.operation.ExpireWaitKeysOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKeyContainer
 
getFactoryId() - Method in class com.hazelcast.cp.internal.datastructures.spi.operation.DestroyRaftObjectOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.MembershipChangeSchedule.CPGroupMembershipChange
 
getFactoryId() - Method in class com.hazelcast.cp.internal.MembershipChangeSchedule
 
getFactoryId() - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
getFactoryId() - Method in class com.hazelcast.cp.internal.operation.ChangeRaftGroupMembershipOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.operation.DefaultRaftReplicateOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.operation.DestroyRaftGroupOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.operation.GetLeadedGroupsOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.operation.integration.AsyncRaftOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.operation.RaftQueryOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.operation.RestartCPMemberOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.operation.TransferLeadershipOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.operation.unsafe.AbstractUnsafeRaftOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.operation.unsafe.UnsafeSnapshotReplicationOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.operation.unsafe.UnsafeStateReplicationOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raft.command.DestroyRaftGroupCmd
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raft.impl.command.UpdateRaftGroupMembersCmd
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendFailureResponse
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendRequest
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendSuccessResponse
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raft.impl.dto.InstallSnapshot
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raft.impl.dto.PreVoteRequest
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raft.impl.dto.PreVoteResponse
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raft.impl.dto.TriggerLeaderElection
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raft.impl.dto.VoteRequest
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raft.impl.dto.VoteResponse
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raft.impl.log.LogEntry
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raft.impl.RaftDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.cp.internal.RaftEndpointImpl
 
getFactoryId() - Method in class com.hazelcast.cp.internal.RaftGroupId
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.GetInitialRaftGroupMembersIfCurrentGroupMemberOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.metadata.AddCPMemberOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.metadata.CompleteDestroyRaftGroupsOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.metadata.CompleteRaftGroupMembershipChangesOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.metadata.CreateRaftGroupOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.metadata.CreateRaftNodeOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.metadata.DestroyRaftNodesOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.metadata.ForceDestroyRaftGroupOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetActiveCPMembersOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetActiveRaftGroupByNameOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetActiveRaftGroupIdsOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetDestroyingRaftGroupIdsOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetMembershipChangeScheduleOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetRaftGroupIdsOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetRaftGroupOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.metadata.InitMetadataRaftGroupOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.metadata.PublishActiveCPMembersOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.metadata.RaftServicePreJoinOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.metadata.RemoveCPMemberOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.metadata.TriggerDestroyRaftGroupOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.NotifyTermChangeOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.raftop.snapshot.RestoreSnapshotOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.cp.internal.session.CPSessionInfo
 
getFactoryId() - Method in class com.hazelcast.cp.internal.session.operation.CloseInactiveSessionsOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.session.operation.CloseSessionOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.session.operation.CreateSessionOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.session.operation.ExpireSessionsOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.session.operation.GenerateThreadIdOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.session.operation.GetSessionsOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.session.operation.HeartbeatSessionOp
 
getFactoryId() - Method in class com.hazelcast.cp.internal.session.RaftSessionServiceDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.cp.internal.session.SessionResponse
 
getFactoryId() - Method in class com.hazelcast.cp.internal.UnsafeModePartitionState
 
getFactoryId() - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.durableexecutor.impl.operations.ReplicationOperation
 
getFactoryId() - Method in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
 
getFactoryId() - Method in class com.hazelcast.executor.impl.operations.ShutdownOperation
 
getFactoryId() - Method in class com.hazelcast.executor.impl.RunnableAdapter
 
getFactoryId() - Method in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.instance.EndpointQualifier
 
getFactoryId() - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
 
getFactoryId() - Method in class com.hazelcast.internal.ascii.rest.RestValue
 
getFactoryId() - Method in class com.hazelcast.internal.ascii.TextProtocolsDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.BindMessage
 
getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateChange
 
getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateTransactionLogRecord
 
getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.ConfigCheck
 
getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.ExtendedBindMessage
 
getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
 
getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.MembersView
 
getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.MembersViewMetadata
 
getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.operations.AbstractJoinOperation
 
getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.operations.CommitClusterStateOp
 
getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.operations.LockClusterStateOp
 
getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.operations.RollbackClusterStateOp
 
getFactoryId() - Method in class com.hazelcast.internal.cluster.impl.SplitBrainJoinMessage
 
getFactoryId() - Method in class com.hazelcast.internal.cluster.MemberInfo
 
getFactoryId() - Method in class com.hazelcast.internal.crdt.AbstractCRDTReplicationOperation
 
getFactoryId() - Method in class com.hazelcast.internal.crdt.CRDTDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.internal.crdt.pncounter.operations.AbstractPNCounterOperation
 
getFactoryId() - Method in class com.hazelcast.internal.crdt.pncounter.operations.CRDTTimestampedLong
 
getFactoryId() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterImpl
 
getFactoryId() - Method in class com.hazelcast.internal.dynamicconfig.AbstractDynamicConfigOperation
 
getFactoryId() - Method in class com.hazelcast.internal.journal.DeserializingEntry
 
getFactoryId() - Method in class com.hazelcast.internal.journal.EventJournalDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.internal.journal.EventJournalInitialSubscriberState
 
getFactoryId() - Method in class com.hazelcast.internal.locksupport.LockDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
getFactoryId() - Method in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
getFactoryId() - Method in class com.hazelcast.internal.locksupport.operations.LockReplicationOperation
 
getFactoryId() - Method in class com.hazelcast.internal.longregister.LongRegisterDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.internal.longregister.operations.AbstractLongRegisterOperation
 
getFactoryId() - Method in class com.hazelcast.internal.longregister.operations.LongRegisterReplicationOperation
 
getFactoryId() - Method in class com.hazelcast.internal.management.dto.MapConfigDTO
 
getFactoryId() - Method in class com.hazelcast.internal.management.dto.PermissionConfigDTO
 
getFactoryId() - Method in class com.hazelcast.internal.management.ManagementDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.internal.management.operation.AbstractManagementOperation
 
getFactoryId() - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.CacheBrowserEntryView
 
getFactoryId() - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.GetCacheEntryViewEntryProcessor
 
getFactoryId() - Method in class com.hazelcast.internal.metrics.managementcenter.MetricsDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.internal.metrics.managementcenter.ReadMetricsOperation
 
getFactoryId() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidation
 
getFactoryId() - Method in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.internal.partition.impl.PartitionPortableHook
 
getFactoryId() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
getFactoryId() - Method in class com.hazelcast.internal.partition.MigrationStateImpl
 
getFactoryId() - Method in class com.hazelcast.internal.partition.NonFragmentedServiceNamespace
 
getFactoryId() - Method in class com.hazelcast.internal.partition.PartitionLostEventImpl
 
getFactoryId() - Method in class com.hazelcast.internal.partition.PartitionReplica
 
getFactoryId() - Method in class com.hazelcast.internal.partition.PartitionRuntimeState
 
getFactoryId() - Method in class com.hazelcast.internal.partition.ReplicaFragmentMigrationState
 
getFactoryId() - Method in class com.hazelcast.internal.partition.ReplicaMigrationEventImpl
 
getFactoryId() - Method in interface com.hazelcast.internal.serialization.DataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
 
getFactoryId(String, int) - Static method in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
getFactoryId() - Method in class com.hazelcast.internal.serialization.impl.FieldDefinitionImpl
 
getFactoryId() - Method in interface com.hazelcast.internal.serialization.PortableHook
 
getFactoryId() - Method in class com.hazelcast.internal.services.DistributedObjectNamespace
 
getFactoryId() - Method in class com.hazelcast.internal.usercodedeployment.impl.ClassData
 
getFactoryId() - Method in class com.hazelcast.internal.usercodedeployment.impl.operation.ClassDataFinderOperation
 
getFactoryId() - Method in class com.hazelcast.internal.usercodedeployment.impl.operation.DeployClassesOperation
 
getFactoryId() - Method in class com.hazelcast.internal.usercodedeployment.impl.UserCodeDeploymentSerializerHook
 
getFactoryId() - Method in class com.hazelcast.map.eviction.LFUEvictionPolicy
 
getFactoryId() - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
 
getFactoryId() - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
 
getFactoryId() - Method in class com.hazelcast.map.impl.client.MapPortableHook
 
getFactoryId() - Method in class com.hazelcast.map.impl.EntryEventFilter
 
getFactoryId() - Method in class com.hazelcast.map.impl.EntryRemovingProcessor
 
getFactoryId() - Method in class com.hazelcast.map.impl.EventListenerFilter
 
getFactoryId() - Method in class com.hazelcast.map.impl.iterator.AbstractCursor
 
getFactoryId() - Method in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
 
getFactoryId() - Method in class com.hazelcast.map.impl.journal.MapEventJournalReadOperation
 
getFactoryId() - Method in class com.hazelcast.map.impl.journal.MapEventJournalReadResultSetImpl
 
getFactoryId() - Method in class com.hazelcast.map.impl.LazyMapEntry
 
getFactoryId() - Method in class com.hazelcast.map.impl.LockAwareLazyMapEntry
 
getFactoryId() - Method in class com.hazelcast.map.impl.MapDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.map.impl.MapEntries
 
getFactoryId() - Method in class com.hazelcast.map.impl.MapKeySet
 
getFactoryId() - Method in class com.hazelcast.map.impl.MapPartitionLostEventFilter
 
getFactoryId() - Method in class com.hazelcast.map.impl.MapValueCollection
 
getFactoryId() - Method in class com.hazelcast.map.impl.MerkleTreeNodeEntries
 
getFactoryId() - Method in class com.hazelcast.map.impl.nearcache.invalidation.UuidFilter
 
getFactoryId() - Method in class com.hazelcast.map.impl.operation.AbstractMapOperationFactory
 
getFactoryId() - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperation
 
getFactoryId() - Method in class com.hazelcast.map.impl.operation.MapGetInvalidationMetaDataOperation
 
getFactoryId() - Method in class com.hazelcast.map.impl.operation.MapGetInvalidationMetaDataOperation.MetaDataResponse
 
getFactoryId() - Method in class com.hazelcast.map.impl.operation.MapNearCacheStateHolder
 
getFactoryId() - Method in class com.hazelcast.map.impl.operation.MapOperation
 
getFactoryId() - Method in class com.hazelcast.map.impl.operation.MapReplicationOperation
 
getFactoryId() - Method in class com.hazelcast.map.impl.operation.MapReplicationStateHolder
 
getFactoryId() - Method in class com.hazelcast.map.impl.operation.MergeOperationFactory
 
getFactoryId() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperationFactory
 
getFactoryId() - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
 
getFactoryId() - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation.InterceptorInfo
 
getFactoryId() - Method in class com.hazelcast.map.impl.operation.PutAllPartitionAwareOperationFactory
 
getFactoryId() - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
 
getFactoryId() - Method in class com.hazelcast.map.impl.operation.WriteBehindStateHolder
 
getFactoryId() - Method in class com.hazelcast.map.impl.query.AggregationResult
 
getFactoryId() - Method in class com.hazelcast.map.impl.query.Query
 
getFactoryId() - Method in class com.hazelcast.map.impl.query.QueryOperation
 
getFactoryId() - Method in class com.hazelcast.map.impl.query.QueryResult
 
getFactoryId() - Method in class com.hazelcast.map.impl.query.QueryResultRow
 
getFactoryId() - Method in class com.hazelcast.map.impl.query.ResultSegment
 
getFactoryId() - Method in class com.hazelcast.map.impl.query.Target
 
getFactoryId() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
 
getFactoryId() - Method in class com.hazelcast.map.impl.querycache.accumulator.ConsumeAccumulatorOperation
 
getFactoryId() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.DestroyQueryCacheOperation
 
getFactoryId() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.MadePublishableOperation
 
getFactoryId() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.MadePublishableOperationFactory
 
getFactoryId() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.PublisherCreateOperation
 
getFactoryId() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.ReadAndResetAccumulatorOperation
 
getFactoryId() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.SetReadCursorOperation
 
getFactoryId() - Method in class com.hazelcast.map.impl.record.RecordInfo
 
getFactoryId() - Method in class com.hazelcast.map.impl.SimpleEntryView
 
getFactoryId() - Method in class com.hazelcast.map.impl.tx.MapTransactionLogRecord
 
getFactoryId() - Method in class com.hazelcast.map.impl.tx.VersionedValue
 
getFactoryId() - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
 
getFactoryId() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
 
getFactoryId() - Method in class com.hazelcast.map.impl.wan.WanMapEntryView
 
getFactoryId() - Method in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.multimap.impl.MultiMapEventFilter
 
getFactoryId() - Method in class com.hazelcast.multimap.impl.MultiMapMergeContainer
 
getFactoryId() - Method in class com.hazelcast.multimap.impl.MultiMapRecord
 
getFactoryId() - Method in class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
 
getFactoryId() - Method in class com.hazelcast.multimap.impl.operations.EntrySetResponse
 
getFactoryId() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
 
getFactoryId() - Method in class com.hazelcast.multimap.impl.operations.MultiMapReplicationOperation
 
getFactoryId() - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
 
getFactoryId() - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
 
getFactoryId() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
Returns the factory ID.
getFactoryId() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
getFactoryId() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
getFactoryId() - Method in interface com.hazelcast.nio.serialization.IdentifiedDataSerializable
Returns DataSerializableFactory factory ID for this class.
getFactoryId() - Method in interface com.hazelcast.nio.serialization.Portable
Returns PortableFactory ID for this portable class
getFactoryId() - Method in class com.hazelcast.projection.impl.IdentityProjection
 
getFactoryId() - Method in class com.hazelcast.projection.impl.MultiAttributeProjection
 
getFactoryId() - Method in class com.hazelcast.projection.impl.ProjectionDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.projection.impl.SingleAttributeProjection
 
getFactoryId() - Method in class com.hazelcast.query.impl.CompositeValue
 
getFactoryId() - Method in class com.hazelcast.query.impl.MapIndexInfo
 
getFactoryId() - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
 
getFactoryId() - Method in class com.hazelcast.query.impl.predicates.AndPredicate
 
getFactoryId() - Method in class com.hazelcast.query.impl.predicates.FalsePredicate
 
getFactoryId() - Method in class com.hazelcast.query.impl.predicates.InstanceOfPredicate
 
getFactoryId() - Method in class com.hazelcast.query.impl.predicates.NotPredicate
 
getFactoryId() - Method in class com.hazelcast.query.impl.predicates.OrPredicate
 
getFactoryId() - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
 
getFactoryId() - Method in class com.hazelcast.query.impl.predicates.PartitionPredicateImpl
 
getFactoryId() - Method in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.query.impl.predicates.SqlPredicate
 
getFactoryId() - Method in class com.hazelcast.query.impl.predicates.TruePredicate
 
getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
 
getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeys
 
getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
 
getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
 
getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapValueCollection
 
getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.AbstractSerializableOperation
 
getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperation
 
getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperationFactory
 
getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.MergeOperationFactory
 
getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.PutAllOperationFactory
 
getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.VersionResponsePair
 
getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
 
getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
 
getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.operations.AbstractRingBufferOperation
 
getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.operations.MergeOperation
 
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.RingbufferContainer
 
getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.HashMapAdapter
 
getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.NamedTaskDecorator
 
getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.AbstractSchedulerOperation
 
getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnPartitionOperationFactory
 
getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.operations.ReplicationOperation
 
getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledRunnableAdapter
 
getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskDescriptor
 
getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
 
getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskResult
 
getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskStatisticsImpl
 
getFactoryId() - Method in class com.hazelcast.scheduledexecutor.impl.TaskDefinition
 
getFactoryId() - Method in class com.hazelcast.security.SimpleTokenCredentials
 
getFactoryId() - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
getFactoryId() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventEnvelope
 
getFactoryId() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.OnJoinRegistrationOperation
 
getFactoryId() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.SendEventOperation
 
getFactoryId() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
 
getFactoryId() - Method in class com.hazelcast.spi.impl.eventservice.impl.TrueEventFilter
 
getFactoryId() - Method in class com.hazelcast.spi.impl.merge.AbstractCollectionMergingValueImpl
 
getFactoryId() - Method in class com.hazelcast.spi.impl.merge.AbstractMergingEntryImpl
 
getFactoryId() - Method in class com.hazelcast.spi.impl.merge.AbstractMergingValueImpl
 
getFactoryId() - Method in class com.hazelcast.spi.impl.merge.AbstractSplitBrainMergePolicy
 
getFactoryId() - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
getFactoryId() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
getFactoryId() - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
getFactoryId() - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
getFactoryId() - Method in class com.hazelcast.spi.impl.merge.RingbufferMergingValueImpl
 
getFactoryId() - Method in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.spi.impl.operationservice.AbstractLocalOperation
 
getFactoryId() - Method in class com.hazelcast.spi.impl.operationservice.BinaryOperationFactory
 
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.operationservice.OperationControl
 
getFactoryId() - Method in class com.hazelcast.spi.impl.PortableCachePartitionLostEvent
 
getFactoryId() - Method in class com.hazelcast.spi.impl.PortableCollection
 
getFactoryId() - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
 
getFactoryId() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
 
getFactoryId() - Method in class com.hazelcast.spi.impl.PortableItemEvent
 
getFactoryId() - Method in class com.hazelcast.spi.impl.PortableMapPartitionLostEvent
 
getFactoryId() - Method in class com.hazelcast.spi.impl.PortablePartitionLostEvent
 
getFactoryId() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.DistributedObjectDestroyOperation
 
getFactoryId() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.InitializeDistributedObjectOperation
 
getFactoryId() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.PostJoinProxyOperation
 
getFactoryId() - Method in class com.hazelcast.spi.impl.SerializableList
 
getFactoryId() - Method in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.spi.impl.SpiPortableHook
 
getFactoryId() - Method in class com.hazelcast.spi.impl.tenantcontrol.NoopTenantControl
 
getFactoryId() - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
 
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.transaction.impl.operations.AbstractTxOperation
 
getFactoryId() - Method in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.transaction.impl.xa.operations.AbstractXAOperation
 
getFactoryId() - Method in class com.hazelcast.transaction.impl.xa.operations.XaReplicationOperation
 
getFactoryId() - Method in class com.hazelcast.transaction.impl.xa.XATransactionDTO
 
getFactoryId() - Method in class com.hazelcast.version.MemberVersion
 
getFactoryId() - Method in class com.hazelcast.version.Version
 
getFactoryId() - Method in class com.hazelcast.wan.impl.WanDataSerializerHook
 
getFactoryImpl() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
getFactoryImplementation() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
getFactoryImplementation() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueueStoreConfigHolder
 
getFactoryImplementation() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.RingbufferStoreConfigHolder
 
getFactoryImplementation() - Method in class com.hazelcast.config.MapStoreConfig
Returns the map store factory implementation object.
getFactoryImplementation() - Method in class com.hazelcast.config.MCMutualAuthConfig
Returns the factory implementation object.
getFactoryImplementation() - Method in class com.hazelcast.config.QueueStoreConfig
 
getFactoryImplementation() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getFactoryImplementation() - Method in class com.hazelcast.config.SSLConfig
Returns the factory implementation object.
getFailoverConfig() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getFeature(String, String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getFence() - Method in class com.hazelcast.client.cp.internal.datastructures.lock.FencedLockProxy
 
getFence() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockOwnershipState
Returns fencing token of the lock if it is currently hold by some endpoint.
getFence() - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
getFence() - Method in interface com.hazelcast.cp.lock.FencedLock
Returns the fencing token if the lock is held by the current thread.
getField(String) - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
 
getField(int) - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
 
getField(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
Gets the FieldDefinition for a particular field.
getField(int) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
Gets the FieldDefinition for a given fieldIndex.
getFieldClassId(String) - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
 
getFieldClassId(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
getFieldClassId(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
Gets the class ID of a field.
getFieldClassId(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
getFieldCount() - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
 
getFieldCount() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
Returns the field count.
getFieldDefinition(ClassDefinition, String) - Method in interface com.hazelcast.internal.serialization.PortableContext
 
getFieldNames() - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
 
getFieldNames() - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
getFieldNames() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
Returns a Set of all field names.
getFieldNames() - Method in interface com.hazelcast.nio.serialization.PortableReader
 
getFieldType(String) - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
 
getFieldType(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
getFieldType(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
Get the FieldType for a given fieldName.
getFieldType(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
getFileFromResources(String) - Static method in class com.hazelcast.internal.nio.IOUtil
 
getFileFromResourcesAsStream(String) - Static method in class com.hazelcast.internal.nio.IOUtil
 
getFilter() - Method in class com.hazelcast.client.impl.querycache.subscriber.ListenerInfo
 
getFilter() - Method in interface com.hazelcast.spi.impl.eventservice.EventRegistration
Returns the EventFilter attached to this registration.
getFilter() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
 
getFilters() - Method in class com.hazelcast.config.WanReplicationRef
Returns the list of class names implementing the CacheWanEventFilter or MapWanEventFilter for filtering outbound WAN replication events.
getFinalPartitionVersion() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
getFirst(Iterable<T>, T) - Static method in class com.hazelcast.internal.util.IterableUtil
 
getFirstChild() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
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.internal.nio.Packet
 
getFlags() - Method in class com.hazelcast.query.impl.predicates.ILikePredicate
 
getFlags() - Method in class com.hazelcast.query.impl.predicates.LikePredicate
 
getFlakeIdGenerator(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getFlakeIdGenerator(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getFlakeIdGenerator(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns a cluster-wide unique ID generator.
getFlakeIdGenerator(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getFlakeIdGenerator(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.client.config.ClientConfig
Returns the ClientFlakeIdGeneratorConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.config.Config
Returns the FlakeIdGeneratorConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getFlakeIdGeneratorConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getFlakeIdGeneratorConfigMap() - Method in class com.hazelcast.client.config.ClientConfig
Returns the map of FlakeIdGenerator configurations, mapped by config name.
getFlakeIdGeneratorConfigs() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getFlakeIdGeneratorConfigs() - Method in class com.hazelcast.config.Config
Returns the map of FlakeIdGenerator configurations, mapped by config name.
getFlakeIdGeneratorConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
getFlakeIdGeneratorConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Returns all registered FlakeIdGenerator configurations.
getFlakeIdGeneratorConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getFloat(String, float) - Method in class com.hazelcast.internal.json.JsonObject
Returns the float value of the member with the specified name in this object.
getFloat(Object, long) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Returns the float value at the supplied offset from the supplied object's base address.
getFloat(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getFloat(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getFloat(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getFloat(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getFloat(long) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Reads the float value from given address.
getFloat(JsonObject, String) - Static method in class com.hazelcast.internal.util.JsonUtil
Returns a field in a Json object as a float.
getFloat(JsonObject, String, float) - Static method in class com.hazelcast.internal.util.JsonUtil
Returns a field in a Json object as a float.
getFloat(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured float value of a HazelcastProperty.
getFloatVolatile(Object, long) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Reads the float value as volatile from given object by its offset.
getFloatVolatile(long) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Reads the float value as volatile from given object by its offset.
getFloatVolatile(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getFloatVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getFloatVolatile(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getFloatVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getFlushSequences() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
getFollowerState(RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.state.LeaderState
 
getFollowerStates() - Method in class com.hazelcast.cp.internal.raft.impl.state.LeaderState
 
getFormatId() - Method in class com.hazelcast.transaction.impl.xa.SerializableXID
 
getForUpdate(Object) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
getForUpdate(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
getForUpdate(Object) - Method in interface com.hazelcast.transaction.TransactionalMap
Locks the key and then gets and returns the value to which the specified key is mapped.
getFragments(int, ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.util.ClientMessageSplitter
Splits a ClientMessage into fragments of a maximum size.
getFrameLength() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
getFrameLength() - Method in class com.hazelcast.internal.ascii.AbstractTextCommand
 
getFrameLength() - Method in interface com.hazelcast.internal.networking.OutboundFrame
Returns the frame length.
getFrameLength() - Method in class com.hazelcast.internal.nio.Packet
 
getFreeHeap() - Method in class com.hazelcast.internal.memory.DefaultMemoryStats
 
getFreeHeap() - Method in interface com.hazelcast.internal.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.internal.util.MemoryInfoAccessor
Returns the amount of free memory in the Java virtual machine in bytes.
getFreeMemory() - Method in class com.hazelcast.internal.util.RuntimeMemoryInfoAccessor
 
getFreeNative() - Method in class com.hazelcast.internal.memory.DefaultMemoryStats
 
getFreeNative() - Method in interface com.hazelcast.internal.memory.MemoryStats
Returns the amount of free native memory in current HazelcastInstance in bytes.
getFreeNative() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
getFreePhysical() - Method in class com.hazelcast.internal.memory.DefaultMemoryStats
 
getFreePhysical() - Method in interface com.hazelcast.internal.memory.MemoryStats
Returns free physical memory available in OS.
getFreePhysical() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
getFrom() - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
 
getFrom() - Method in class com.hazelcast.query.impl.predicates.BoundedRangePredicate
 
getFrom() - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
 
getFrom() - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
 
getFrom() - Method in interface com.hazelcast.query.impl.predicates.RangePredicate
 
getFromCache(String) - Static method in class com.hazelcast.internal.usercodedeployment.impl.ThreadLocalClassCache
 
getFunction() - Method in class com.hazelcast.spi.properties.HazelcastProperty
 
getFunctionClassName() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
getFunctionImplementation() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
getFuture() - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
getGcpConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the current GcpConfig.
getGcpConfig() - Method in class com.hazelcast.config.JoinConfig
 
getGcpConfig() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the GcpConfig used by the discovery mechanism for this WAN publisher.
getGCStats() - Method in class com.hazelcast.internal.memory.DefaultMemoryStats
 
getGCStats() - Static method in class com.hazelcast.internal.memory.GCStatsSupport
 
getGCStats() - Method in interface com.hazelcast.internal.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.impl.OperationExecutorImpl
 
getGenericOperationRunners() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
Gets all the generic operation handlers.
getGenericThreadCount() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
getGenericThreadCount() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
Returns the number of generic threads.
getGenericThreadCount() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
getGenericThreadCount() - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Returns the number of generic threads.
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.EmptyLocalReplicatedMapStats
 
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
getGlobalMemoryAccessor(GlobalMemoryAccessorType) - Static method in class com.hazelcast.internal.memory.GlobalMemoryAccessorRegistry
Returns the MemoryAccessor instance appropriate to the given GlobalMemoryAccessorType.
getGlobalSerializerConfig() - Method in class com.hazelcast.config.SerializationConfig
 
getGlobalTaskScheduler() - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
getGlobalTaskScheduler() - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
getGlobalTransactionId() - Method in class com.hazelcast.transaction.impl.xa.SerializableXID
 
getGroup(CPGroupId) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
getGroupId() - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
getGroupId() - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
getGroupId() - Method in class com.hazelcast.client.cp.internal.datastructures.countdownlatch.CountDownLatchProxy
 
getGroupId() - Method in class com.hazelcast.client.cp.internal.datastructures.lock.FencedLockProxy
 
getGroupId() - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionAwareSemaphoreProxy
 
getGroupId() - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionlessSemaphoreProxy
 
getGroupId() - Method in exception com.hazelcast.cp.exception.CPGroupDestroyedException
 
getGroupId() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
getGroupId() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
getGroupId() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.proxy.CountDownLatchProxy
 
getGroupId() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.BlockingResource
 
getGroupId() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
getGroupId() - Method in class com.hazelcast.cp.internal.operation.unsafe.AbstractUnsafeRaftOp
 
getGroupId() - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Returns the groupId which this node belongs to.
getGroupId() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
getGroupId() - Method in class com.hazelcast.cp.internal.session.SessionAwareProxy
 
getGroupId() - Method in interface com.hazelcast.cp.lock.FencedLock
Returns id of the CP group that runs this FencedLock instance
getGroupIds() - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
getGroupIdSet() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
getGroupNameForProxy(String) - Static method in class com.hazelcast.cp.internal.RaftService
 
getGroups() - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
getGroupSize() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the number of CP members to form CP groups.
getGroupType() - Method in class com.hazelcast.config.PartitionGroupConfig
Returns the MemberGroupType configured.
getHandler() - Method in class com.hazelcast.client.impl.proxy.ClientScheduledFutureProxy
 
getHandler() - Method in class com.hazelcast.client.impl.spi.impl.listener.ClientRegistrationKey
 
getHandler() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledFutureProxy
 
getHandler() - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
Returns the scheduled future resource handler.
getHandlers() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingTask
 
getHazelcastClientByName(String) - Static method in class com.hazelcast.client.HazelcastClient
Returns an existing HazelcastClient with instanceName.
getHazelcastInstance() - Method in interface com.hazelcast.cache.HazelcastCacheManager
Gets the underlying HazelcastInstance implementation.
getHazelcastInstance() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
getHazelcastInstance() - Method in class com.hazelcast.client.impl.spi.ClientContext
 
getHazelcastInstance() - Method in class com.hazelcast.client.impl.spi.ProxyManager
 
getHazelcastInstance(String) - Static method in class com.hazelcast.instance.impl.HazelcastInstanceFactory
 
getHazelcastInstance() - Method in class com.hazelcast.internal.eviction.ExpirationManager
 
getHazelcastInstance() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getHazelcastInstance() - Method in class com.hazelcast.internal.management.ManagementCenterService
 
getHazelcastInstance() - Method in interface com.hazelcast.spi.impl.NodeEngine
Returns the HazelcastInstance that this NodeEngine belongs to.
getHazelcastInstance() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getHazelcastInstance() - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
 
getHazelcastInstanceByName(String) - Static method in class com.hazelcast.core.Hazelcast
Returns an existing HazelcastInstance with instanceName.
getHazelcastInstanceByName(String) - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Gets an existing HazelcastOSGiInstance with its instanceName.
getHazelcastModuleName() - Static method in class com.hazelcast.internal.util.ModularJavaUtils
 
getHazelcastName() - Method in interface com.hazelcast.internal.nio.IOService
 
getHazelcastName() - Method in class com.hazelcast.internal.nio.NodeIOService
 
getHeaderFlags() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
getHeadSeq() - Method in exception com.hazelcast.ringbuffer.StaleSequenceException
Returns the last known head sequence.
getHeadSequence(StaleSequenceException) - Method in class com.hazelcast.client.impl.proxy.ClientReliableMessageRunner
 
getHeadSequence() - Method in interface com.hazelcast.map.impl.querycache.accumulator.CyclicBuffer
Returns the sequence number of the element in the head index of this buffer if there exists any, otherwise -1L will be returned.
getHeadSequence() - Method in class com.hazelcast.map.impl.querycache.accumulator.DefaultCyclicBuffer
 
getHeadSequence() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Returns the sequence of the head.
getHeadSequence(StaleSequenceException) - Method in class com.hazelcast.topic.impl.reliable.MessageRunner
 
getHeadSequence(StaleSequenceException) - Method in class com.hazelcast.topic.impl.reliable.ReliableMessageRunner
 
getHeapCost() - Method in class com.hazelcast.internal.serialization.impl.HeapData
 
getHeapCost() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
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 & Merkle trees in bytes
getHeapCost() - Method in interface com.hazelcast.nio.serialization.Data
Returns approximate heap cost of this Data object in bytes.
getHeartbeatBroadcastPeriodMillis() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationMonitor
 
getHeartbeatIntervalMillis() - Method in class com.hazelcast.internal.cluster.impl.ClusterHeartbeatManager
 
getHeartbeatIntervalMillis() - Method in class com.hazelcast.splitbrainprotection.impl.ProbabilisticSplitBrainProtectionFunction
 
getHeartbeatMillis() - Method in class com.hazelcast.cp.internal.session.SessionResponse
 
getHeartbeatPerMember() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationMonitor
 
getHeartbeatToleranceMillis() - Method in class com.hazelcast.splitbrainprotection.impl.RecentlyActiveSplitBrainProtectionFunction
 
getHitCount() - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
getHitCount() - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
 
getHitCount() - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Returns the hit count.
getHitCount() - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
getHitCount() - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Returns the total number of hits into the index.
getHitCount() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the total number of hits into the index.
getHits() - Method in interface com.hazelcast.core.EntryView
Returns number of hits of the entry.
getHits() - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
getHits() - Method in interface com.hazelcast.map.impl.record.Record
 
getHits() - Method in class com.hazelcast.map.impl.record.RecordInfo
 
getHits() - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
 
getHits() - Method in class com.hazelcast.map.impl.SimpleEntryView
 
getHits() - Method in class com.hazelcast.map.impl.wan.WanMapEntryView
 
getHits() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
getHits() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
getHits() - Method in class com.hazelcast.monitor.impl.LocalRecordStoreStatsImpl
 
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 locally owned entries, including those which are no longer in the map (for example, may have been evicted).
getHits() - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Returns the number of hits (reads) of the locally owned entries of this partition.
getHits() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the number of hits (reads) of Near Cache entries owned by this member.
getHits() - Method in class com.hazelcast.multimap.impl.MultiMapMergeContainer
 
getHits() - Method in class com.hazelcast.multimap.impl.MultiMapValue
 
getHits() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
getHits() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
getHits() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
getHits() - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
getHits() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
getHits() - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
getHits() - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
getHits() - Method in interface com.hazelcast.spi.merge.MergingHits
Returns the access hits of the merge data.
getHost() - Method in class com.hazelcast.cluster.Address
 
getHost() - Method in class com.hazelcast.spi.discovery.multicast.impl.MulticastMemberInfo
 
getHostHeader() - Method in class com.hazelcast.config.AwsConfig
getHotRestartConfig() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
getHotRestartConfig() - Method in class com.hazelcast.config.AbstractCacheConfig
Gets the HotRestartConfig for this CacheConfiguration
getHotRestartConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the HotRestartConfig for this CacheSimpleConfig
getHotRestartConfig() - Method in class com.hazelcast.config.MapConfig
Gets the HotRestartConfig for this MapConfig
getHotRestartConfig() - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
getHotRestartConfig() - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
getHotRestartPersistenceConfig() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getHotRestartPersistenceConfig() - Method in class com.hazelcast.config.Config
Returns the Hot Restart configuration for this hazelcast instance
getHotRestartPersistenceConfig() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getHotRestartService() - Method in class com.hazelcast.client.impl.proxy.ClientClusterProxy
 
getHotRestartService() - Method in interface com.hazelcast.cluster.Cluster
Returns the Hot Restart service for interacting with Hot Restart.
getHotRestartService() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
getHotRestartService() - Method in interface com.hazelcast.instance.impl.NodeExtension
Returns the public hot restart service
getHotRestartService() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getHotRestartState() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
getHotRestartState() - Method in interface com.hazelcast.monitor.MemberState
 
getHotRestartStatus() - Method in class com.hazelcast.internal.management.dto.ClusterHotRestartStatusDTO
 
getHzPort() - Method in class com.hazelcast.config.AwsConfig
getIamRole() - Method in class com.hazelcast.config.AwsConfig
getIcmpFailureDetectorConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig
Returns the current IcmpFailureDetectorConfig.
getIcmpFailureDetectorConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getIcmpFailureDetectorConfig() - Method in class com.hazelcast.config.NetworkConfig
Returns the current IcmpFailureDetectorConfig.
getId() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getId() - Method in enum com.hazelcast.client.impl.protocol.AuthenticationStatus
 
getId() - Method in class com.hazelcast.client.impl.querycache.subscriber.ListenerInfo
 
getId() - Method in class com.hazelcast.client.impl.spi.ClientProxy
Deprecated.
getId() - Method in enum com.hazelcast.cluster.MemberAttributeOperationType
Gets the ID of the MemberAttributeOperationType.
getId() - Method in enum com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
 
getId() - Method in enum com.hazelcast.config.ConsistencyCheckStrategy
Gets the ID for this ConsistencyCheckStrategy.
getId() - Method in enum com.hazelcast.config.IndexType
Gets the ID for the given IndexType.
getId() - Method in enum com.hazelcast.config.MetadataPolicy
Returns enumeration id of this policy.
getId() - Method in enum com.hazelcast.config.WanAcknowledgeType
Gets the ID for the given WanAcknowledgeType.
getId() - Method in enum com.hazelcast.config.WanPublisherState
Returns the ID of the WAN publisher state.
getId() - Method in enum com.hazelcast.config.WanQueueFullBehavior
Gets the ID for the given WanQueueFullBehavior.
getId() - Method in interface com.hazelcast.cp.CPGroupId
Returns unique id of the CP group.
getId() - Method in class com.hazelcast.cp.internal.RaftGroupId
 
getId() - Method in enum com.hazelcast.internal.util.IterationType
Gets the ID for the given IterationType.
getId() - Method in enum com.hazelcast.nio.serialization.FieldType
 
getId() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Gets the ID of service.
getId() - Method in enum com.hazelcast.ringbuffer.OverflowPolicy
Gets the ID for the given OverflowPolicy.
getId() - Method in enum com.hazelcast.scheduledexecutor.impl.TaskDefinition.Type
 
getId() - Method in interface com.hazelcast.spi.impl.eventservice.EventRegistration
Returns the event registration ID.
getId() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
 
getId2InterceptorMap() - Method in class com.hazelcast.map.impl.InterceptorRegistry
 
getIdCount() - Method in class com.hazelcast.monitor.impl.LocalFlakeIdGeneratorStatsImpl
 
getIdCount() - Method in interface com.hazelcast.monitor.LocalFlakeIdGeneratorStats
Note that the ID count returned is the number of generated IDs not the number of consumed IDs.
getIdentifier() - Method in class com.hazelcast.instance.EndpointQualifier
 
getIdleMaxParkNs() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the maximum duration in nanoseconds that the WAN replication thread will be parked if there are no events to replicate.
getIdleMinParkNs() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the minimum duration in nanoseconds that the WAN replication thread will be parked if there are no events to replicate.
getIdlenessStartTime(Record) - Static method in class com.hazelcast.map.impl.ExpirationTimeSetter
Returns last-access-time of an entry if it was accessed before, otherwise it returns creation-time of the entry.
getIdleStrategy(HazelcastProperties, HazelcastProperty) - Static method in class com.hazelcast.spi.impl.operationservice.impl.InboundResponseHandlerSupplier
 
getIdOffset() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getIfSameKey(K) - Method in interface com.hazelcast.map.impl.recordstore.Storage
Gives the same result as Storage.get(Object), but with the additional constraint that the supplied key must not just be equal to, but be exactly the same key blob (at the same memory address) as the one stored.
getIfSameKey(Data) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
getIgnoredPublisherIds() - Method in class com.hazelcast.wan.impl.AddWanConfigResult
Returns the IDs for the WAN publishers which were ignored and not added to the configuration.
getImpl() - Method in class com.hazelcast.map.impl.MapStoreWrapper
 
getImplementation() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
getImplementation() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.PredicateConfigHolder
 
getImplementation() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueueStoreConfigHolder
 
getImplementation() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.RingbufferStoreConfigHolder
 
getImplementation() - Method in class com.hazelcast.config.AbstractWanPublisherConfig
Returns the implementation of WanReplicationPublisher.
getImplementation() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
 
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.LoginModuleConfig
Deprecated.
getImplementation() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
 
getImplementation() - Method in class com.hazelcast.config.MapStoreConfig
Returns the map store implementation object.
getImplementation() - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
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.SecurityInterceptorConfig
 
getImplementation() - Method in class com.hazelcast.config.SerializerConfig
Returns the implementation of the serializer class.
getImplementation() - Method in class com.hazelcast.config.ServiceConfig
 
getImplementation() - Method in class com.hazelcast.config.SocketInterceptorConfig
Returns the SocketInterceptor implementation object.
getImplementation() - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
 
getImplementation() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
getImplementation() - Method in class com.hazelcast.config.WanConsumerConfig
Returns the implementation implementing WanReplicationConsumer.
getImplementation() - Method in class com.hazelcast.internal.config.CachePartitionLostListenerConfigReadOnly
 
getImplementation() - Method in class com.hazelcast.internal.config.MapPartitionLostListenerConfigReadOnly
 
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.config.AbstractConfigLocator
 
getInboundResponseHandlerSupplier() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
getIncrHits() - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
getIncrMisses() - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
getIndex() - Method in class com.hazelcast.internal.serialization.impl.FieldDefinitionImpl
 
getIndex() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
getIndex(String) - Method in class com.hazelcast.query.impl.Indexes
 
getIndex(QueryContext) - Method in class com.hazelcast.query.impl.predicates.AbstractIndexAwarePredicate
 
getIndex(String) - Method in class com.hazelcast.query.impl.QueryContext
Obtains the index available for the given attribute in this query context.
getIndexConfigFromXml(Node, boolean) - Static method in class com.hazelcast.query.impl.IndexUtils
 
getIndexConfigFromYaml(Node, boolean) - Static method in class com.hazelcast.query.impl.IndexUtils
 
getIndexConfigs() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
getIndexConfigs() - Method in class com.hazelcast.config.MapConfig
 
getIndexConfigs() - Method in class com.hazelcast.config.QueryCacheConfig
 
getIndexConfigs() - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
getIndexConfigs() - Method in class com.hazelcast.internal.config.QueryCacheConfigReadOnly
 
getIndexConfigs() - Method in class com.hazelcast.query.impl.MapIndexInfo
 
getIndexCopyBehavior() - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getIndexDefinitions() - Method in class com.hazelcast.map.impl.MapContainer
 
getIndexedQueryCount() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
getIndexedQueryCount() - Method in class com.hazelcast.monitor.impl.GlobalIndexesStats
 
getIndexedQueryCount() - Method in interface com.hazelcast.monitor.impl.IndexesStats
Returns the number of indexed queries performed on the indexes.
getIndexedQueryCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
getIndexedQueryCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
getIndexedQueryCount() - Method in class com.hazelcast.monitor.impl.PartitionIndexesStats
 
getIndexedQueryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total number of indexed queries performed on the map.
getIndexes() - Method in class com.hazelcast.map.impl.MapContainer
 
getIndexes(int) - Method in class com.hazelcast.map.impl.MapContainer
 
getIndexes() - Method in class com.hazelcast.map.impl.PartitionContainer
 
getIndexes() - Method in class com.hazelcast.query.impl.Indexes
Returns all the indexes known to this indexes instance.
getIndexesStats() - Method in class com.hazelcast.query.impl.Indexes
Returns the indexes stats of this indexes instance.
getIndexProvider(MapConfig) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getIndexStats() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
getIndexStats() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
getIndexStats() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
getIndexStats() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the per-index statistics map keyed by the index name.
getIndexTypeFromXmlName(String) - Static method in class com.hazelcast.query.impl.IndexUtils
 
getInetAddress() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
getInetAddress() - Method in class com.hazelcast.cluster.Address
 
getInetAddress() - Method in class com.hazelcast.cluster.impl.AbstractMember
 
getInetAddress() - Method in interface com.hazelcast.internal.nio.Connection
Returns remote address of this Connection.
getInetAddress() - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
getInetAddressFor(Inet6Address, String) - Static method in class com.hazelcast.internal.util.AddressUtil
 
getInetSocketAddress() - Method in class com.hazelcast.cluster.Address
 
getInfo() - Method in interface com.hazelcast.map.impl.querycache.accumulator.Accumulator
Returns AccumulatorInfo of this accumulator.
getInfo() - Method in class com.hazelcast.map.impl.querycache.accumulator.BasicAccumulator
 
getInfo() - Method in class com.hazelcast.map.impl.querycache.publisher.PartitionAccumulatorRegistry
 
getInitialBackoffMillis() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
how long to wait after the first failure before retrying
getInitialCPMembers() - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
getInitialDelay() - Method in class com.hazelcast.scheduledexecutor.impl.TaskDefinition
 
getInitializationCommitIndices() - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
getInitializationStatus() - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
getInitializedCPMembers() - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
getInitialLoadMode() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
getInitialLoadMode() - Method in class com.hazelcast.config.MapStoreConfig
Returns the initial load mode.
getInitialMembers() - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Returns the initial member list of the Raft group this node belongs to.
getInitialMembers() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
getInitialPartitionVersion() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
getInitialPublisherState() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the initial WAN publisher state.
GetInitialRaftGroupMembersIfCurrentGroupMemberOp - Class in com.hazelcast.cp.internal.raftop
When a CP member is added to a Raft group, a new member list is committed to the Raft group first.
GetInitialRaftGroupMembersIfCurrentGroupMemberOp() - Constructor for class com.hazelcast.cp.internal.raftop.GetInitialRaftGroupMembersIfCurrentGroupMemberOp
 
GetInitialRaftGroupMembersIfCurrentGroupMemberOp(RaftEndpoint) - Constructor for class com.hazelcast.cp.internal.raftop.GetInitialRaftGroupMembersIfCurrentGroupMemberOp
 
getInMemoryFormat() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
getInMemoryFormat() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.NearCacheConfigHolder
 
getInMemoryFormat() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
getInMemoryFormat() - Method in class com.hazelcast.config.CacheConfig
Gets the data type that will be used to store records.
getInMemoryFormat() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the InMemory Format for this ICache.
getInMemoryFormat() - Method in class com.hazelcast.config.MapConfig
Returns the data type that will be used for storing records.
getInMemoryFormat() - Method in class com.hazelcast.config.NearCacheConfig
Returns the data type used to store entries.
getInMemoryFormat() - Method in class com.hazelcast.config.QueryCacheConfig
Returns memory format of values of entries in QueryCache.
getInMemoryFormat() - Method in class com.hazelcast.config.ReplicatedMapConfig
Data type used to store entries.
getInMemoryFormat() - Method in class com.hazelcast.config.RingbufferConfig
Returns the in-memory format.
getInMemoryFormat(String) - Method in class com.hazelcast.spi.impl.merge.AbstractMergeRunnable
 
getInputThreads() - Method in class com.hazelcast.internal.networking.nio.NioNetworking
 
getInsertCount() - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
getInsertCount() - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
 
getInsertCount() - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Returns the insert count.
getInsertCount() - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
getInsertCount() - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Returns the number of insert operations performed on the index.
getInsertCount() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the number of insert operations performed on the index.
getInstanceMBean() - Method in class com.hazelcast.internal.jmx.ManagementService
 
getInstanceName() - Method in class com.hazelcast.client.config.ClientConfig
 
getInstanceName() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getInstanceName() - Method in class com.hazelcast.config.Config
Returns the instance name uniquely identifying the hazelcast instance created by this configuration.
getInstanceName(String, Config) - Static method in class com.hazelcast.instance.impl.HazelcastInstanceFactory
Return real name for the hazelcast instance's instance
getInstanceName() - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
getInstanceName() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
getInstanceName() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getInt(String, int) - Method in class com.hazelcast.internal.json.JsonObject
Returns the int value of the member with the specified name in this object.
getInt(Object, long) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Returns the int value at the supplied offset from the supplied object's base address.
getInt(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getInt(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getInt(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getInt(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getInt(long) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Reads the int value from given address.
getInt(JsonObject, String) - Static method in class com.hazelcast.internal.util.JsonUtil
Returns a field in a Json object as an int.
getInt(JsonObject, String, int) - Static method in class com.hazelcast.internal.util.JsonUtil
Returns a field in a Json object as an int.
getInt(int) - Static method in class com.hazelcast.internal.util.RandomPicker
Returns a pseudorandom, uniformly distributed int value between 0 (inclusive) and the specified value (exclusive), drawn from this random number generator's sequence.
getInt(int, int) - Static method in class com.hazelcast.internal.util.RandomPicker
Return a pseudorandom, uniformly distributed in value between the low value (inclusive) and the high value (exclusive), drawn from this random number generator's sequence.
getInteger(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured int value of a HazelcastProperty.
getIntegerValue(String, String) - Static method in class com.hazelcast.config.DomConfigHelper
 
getIntegerValue(String, String, int) - Static method in class com.hazelcast.config.DomConfigHelper
 
getInterceptorRegistry() - Method in class com.hazelcast.map.impl.MapContainer
 
getInterceptors() - Method in class com.hazelcast.map.impl.InterceptorRegistry
Returns all registered interceptors.
getInterfaces() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getInterfaces() - Method in class com.hazelcast.config.EndpointConfig
 
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(Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
getInternal(Object) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
getInternal(Object) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
getInternalHotRestartService() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
getInternalHotRestartService() - Method in interface com.hazelcast.instance.impl.NodeExtension
Returns the internal hot restart service
getInternalPartitions() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getInternalPartitions() - Method in interface com.hazelcast.internal.partition.InternalPartitionService
 
getInternalWaitKeysMap() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.BlockingResource
 
getIntervalMilliseconds() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
getIntervalMilliseconds() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
getIntVolatile(Object, long) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Reads the int value as volatile from given object by its offset.
getIntVolatile(long) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Reads the int value as volatile from given object by its offset.
getIntVolatile(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getIntVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getIntVolatile(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getIntVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getInvalidationListenerCount() - Method in class com.hazelcast.cache.impl.CacheContext
 
getInvalidationMetaDataFetcher() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingTask
 
getInvalidationRequests() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
getInvalidations() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.BatchNearCacheInvalidation
 
getInvalidations() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
getInvalidations() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the number of invalidations of Near Cache entries owned by this member.
getInvalidationSequence() - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
getInvalidationSequence() - Method in interface com.hazelcast.internal.nearcache.NearCacheRecord
 
getInvalidator() - Method in class com.hazelcast.map.impl.nearcache.MapNearCacheManager
 
getInvocation() - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.protocol.task.AbstractInvocationMessageTask
 
getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
 
getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheFetchNearCacheInvalidationMetadataTask
 
getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
 
getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
 
getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
 
getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
 
getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchNearCacheInvalidationMetadataTask
 
getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.protocol.task.metrics.ReadMetricsMessageTask
 
getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorShutdownMessageTask
 
getInvocationContext() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
getInvocationManager() - Method in class com.hazelcast.cp.internal.RaftService
 
getInvocationMonitor() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
getInvocationRegistry() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
getInvocationRetryPauseMillis() - Method in class com.hazelcast.client.impl.spi.impl.AbstractClientInvocationService
 
getInvocationService() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getInvocationService() - Method in class com.hazelcast.client.impl.spi.ClientContext
 
getInvocationTime() - Method in class com.hazelcast.spi.impl.operationservice.Operation
Gets the time in milliseconds when this invocation started.
getInvocationTimeoutMillis() - Method in class com.hazelcast.client.impl.spi.impl.AbstractClientInvocationService
 
getInvokerWrapper() - Method in class com.hazelcast.client.impl.querycache.ClientQueryCacheContext
 
getInvokerWrapper() - Method in class com.hazelcast.map.impl.querycache.NodeQueryCacheContext
 
getInvokerWrapper() - Method in interface com.hazelcast.map.impl.querycache.QueryCacheContext
Returns InvokerWrapper for this context.
getIOBalancer() - Method in class com.hazelcast.internal.networking.nio.NioNetworking
 
getIoExecutorMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getIoService() - Method in interface com.hazelcast.internal.nio.NetworkingService
Returns the I/O Service
getIoService() - Method in class com.hazelcast.internal.nio.tcp.TcpIpNetworkingService
 
getItem() - Method in class com.hazelcast.collection.impl.common.DataAwareItemEvent
 
getItem() - Method in class com.hazelcast.collection.ItemEvent
Returns the item related to the event.
getItem() - Method in class com.hazelcast.internal.util.collection.WeightedEvictableList.WeightedItem
 
getItem() - Method in class com.hazelcast.spi.impl.PortableItemEvent
 
getItemAtPositionOrNull(T[], int) - Static method in class com.hazelcast.internal.util.collection.ArrayUtils
 
getItemAtPositionOrNull(Collection<T>, int) - Static method in class com.hazelcast.internal.util.CollectionUtil
Returns the n-th item or null if collection is smaller.
getItemData() - Method in class com.hazelcast.collection.impl.common.DataAwareItemEvent
 
getItemId() - Method in class com.hazelcast.collection.impl.collection.CollectionItem
 
getItemId(CollectionTxnOperation) - Static method in class com.hazelcast.collection.impl.CollectionTxnUtil
 
getItemId() - Method in class com.hazelcast.collection.impl.queue.QueueItem
 
getItemId() - Method in interface com.hazelcast.collection.impl.txncollection.CollectionTxnOperation
 
getItemId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
 
getItemId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
 
getItemId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.BaseTxnQueueOperation
 
getItemListenerConfigs() - Method in class com.hazelcast.config.CollectionConfig
Gets the list of ItemListenerConfigs.
getItemListenerConfigs() - Method in class com.hazelcast.config.QueueConfig
Get the list of item listener configurations for this queue.
getItemListenerConfigs() - Method in class com.hazelcast.internal.config.ListConfigReadOnly
 
getItemListenerConfigs() - Method in class com.hazelcast.internal.config.QueueConfigReadOnly
 
getItemListenerConfigs() - Method in class com.hazelcast.internal.config.SetConfigReadOnly
 
getItemQueue() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Returns the item queue on the partition owner.
getItems() - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
 
getItems() - Method in interface com.hazelcast.ringbuffer.impl.Ringbuffer
Returns the array representing this ringbuffer.
getItems() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Returns the array representing this ringbuffer.
getIterationCount() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
 
getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.DefaultMapAggregateMessageTask
 
getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.DefaultMapProjectMessageTask
 
getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPagingPredicateMessageTask
 
getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPredicateMessageTask
 
getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntrySetMessageTask
 
getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
 
getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
 
getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
 
getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesMessageTask
 
getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPagingPredicateMessageTask
 
getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPredicateMessageTask
 
getIterationType() - Method in class com.hazelcast.map.impl.query.Query
 
getIterationType() - Method in class com.hazelcast.map.impl.query.QueryResultCollection
 
getIterationType() - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
 
getIterationType(PagingPredicate) - Static method in class com.hazelcast.query.PagingPredicateAccessor
 
getJaasAuthenticationConfig() - Method in class com.hazelcast.config.security.RealmConfig
 
getJarPaths() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
getJavaSerializationFilterConfig() - Method in class com.hazelcast.config.SerializationConfig
 
getJetBuildInfo() - Method in class com.hazelcast.instance.BuildInfo
 
getJitter() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
by how much to randomize backoffs.
getJoin() - Method in class com.hazelcast.config.AdvancedNetworkConfig
Returns the JoinConfig.
getJoin() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getJoin() - Method in class com.hazelcast.config.NetworkConfig
Returns the JoinConfig.
getJoiner() - Method in class com.hazelcast.instance.impl.Node
 
getJournal() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalReadOperation
 
getJournal() - Method in class com.hazelcast.internal.journal.EventJournalReadOperation
 
getJournal() - Method in class com.hazelcast.map.impl.journal.MapEventJournalReadOperation
 
getKey() - Method in interface com.hazelcast.cache.CacheEntryView
Gets the key of the cache entry.
getKey() - Method in class com.hazelcast.cache.impl.CacheEntry
 
getKey() - Method in class com.hazelcast.cache.impl.CacheEntryEventImpl
 
getKey() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
getKey(int) - Method in class com.hazelcast.cache.impl.CacheKeyIterationResult
 
getKey() - Method in class com.hazelcast.cache.impl.journal.DeserializingEventJournalCacheEvent
 
getKey() - Method in interface com.hazelcast.cache.impl.journal.EventJournalCacheEvent
Returns the key for the event entry.
getKey() - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
 
getKey() - Method in class com.hazelcast.cache.impl.merge.entry.LazyCacheEntryView
 
getKey() - Method in class com.hazelcast.client.impl.protocol.task.multimap.AbstractMultiMapAddEntryListenerMessageTask
 
getKey() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerToKeyMessageTask
 
getKey() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
 
getKey() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
 
getKey() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
 
getKey() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
 
getKey() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
 
getKey() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
 
getKey() - Method in class com.hazelcast.cluster.MemberAttributeEvent
Returns the key for this MemberAttributeEvent.
getKey() - Method in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
 
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 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.MapNameAndKeyPair
 
getKey() - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
 
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.internal.cluster.impl.ClusterStateTransactionLogRecord
 
getKey() - Method in interface com.hazelcast.internal.eviction.EvictableEntryView
Gets the key of the entry.
getKey() - Method in class com.hazelcast.internal.eviction.ExpiredKey
 
getKey() - Method in class com.hazelcast.internal.journal.DeserializingEntry
 
getKey() - Method in interface com.hazelcast.internal.locksupport.LockResource
 
getKey() - Method in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
getKey() - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.CacheBrowserEntryView
 
getKey() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidation
 
getKey() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.SingleNearCacheInvalidation
 
getKey() - Method in class com.hazelcast.internal.nearcache.impl.store.HeapNearCacheRecordMap.NearCacheEvictableSamplingEntry
 
getKey() - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap.SimpleEntry
 
getKey() - Method in interface com.hazelcast.internal.util.executor.StripedRunnable
 
getKey() - Method in class com.hazelcast.internal.util.scheduler.ScheduledEntry
 
getKey() - Method in class com.hazelcast.map.impl.DataAwareEntryEvent
 
getKey() - Method in class com.hazelcast.map.impl.EntryEventFilter
 
getKey() - Method in class com.hazelcast.map.impl.journal.DeserializingEventJournalMapEvent
 
getKey(int) - Method in class com.hazelcast.map.impl.MapEntries
 
getKey() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntry
 
getKey() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
 
getKey() - Method in class com.hazelcast.map.impl.operation.WanEventHolder
 
getKey() - Method in class com.hazelcast.map.impl.query.QueryResultRow
 
getKey() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
getKey() - Method in class com.hazelcast.map.impl.querycache.event.LocalEntryEventData
 
getKey() - Method in interface com.hazelcast.map.impl.querycache.event.QueryCacheEventData
 
getKey() - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
getKey() - Method in interface com.hazelcast.map.impl.record.Record
 
getKey() - Method in class com.hazelcast.map.impl.record.RecordReplicationInfo
 
getKey() - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
 
getKey() - Method in class com.hazelcast.map.impl.SimpleEntryView
 
getKey() - Method in class com.hazelcast.map.impl.tx.MapTransactionLogRecord
 
getKey() - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
 
getKey() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
 
getKey() - Method in class com.hazelcast.map.impl.wan.WanMapEntryView
 
getKey() - Method in interface com.hazelcast.map.journal.EventJournalMapEvent
Returns the key for the event entry.
getKey() - Method in class com.hazelcast.multimap.impl.MultiMapEventFilter
 
getKey() - Method in class com.hazelcast.multimap.impl.MultiMapMergeContainer
 
getKey() - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
 
getKey() - Method in class com.hazelcast.partition.PartitionAwareKey
Gets the key (not the partitionKey).
getKey() - Method in class com.hazelcast.query.impl.CachedQueryEntry
 
getKey() - Method in class com.hazelcast.query.impl.QueryableEntry
 
getKey() - Method in class com.hazelcast.query.impl.QueryEntry
 
getKey(int) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
 
getKey() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
 
getKey() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
getKey() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
getKey() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
getKey() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventProcessor
 
getKey() - Method in class com.hazelcast.spi.impl.eventservice.impl.LocalEventDispatcher
 
getKey() - Method in class com.hazelcast.spi.impl.merge.AbstractMergingEntryImpl
 
getKey() - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
getKey() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
getKey() - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
getKey() - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
getKey() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
 
getKey() - Method in interface com.hazelcast.spi.merge.MergingEntry
Returns the merging key in the in-memory format of the backing data structure.
getKey() - Method in interface com.hazelcast.transaction.impl.TransactionLogRecord
Gets the transaction-log-key that uniquely identifies the TransactionLogRecord within the TransactionLog.
getKey() - Method in interface com.hazelcast.wan.impl.InternalWanReplicationEvent
Returns the key for the entry on which the event occurred.
getKeyClassName() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
getKeyClassName() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getKeyData() - Method in class com.hazelcast.map.impl.DataAwareEntryEvent
 
getKeyData() - Method in class com.hazelcast.map.impl.querycache.event.LocalEntryEventData
 
getKeyData() - Method in class com.hazelcast.query.impl.CachedQueryEntry
 
getKeyData() - Method in class com.hazelcast.query.impl.QueryableEntry
 
getKeyData() - Method in class com.hazelcast.query.impl.QueryEntry
 
getKeyInternal() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
getKeyMetadata() - Method in class com.hazelcast.query.impl.Metadata
 
getKeys() - Method in class com.hazelcast.cache.impl.CacheKeyIterationResult
 
getKeys() - Method in class com.hazelcast.internal.ascii.memcache.BulkGetCommand
 
getKeys() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeys
 
getKeySet() - Method in class com.hazelcast.map.impl.MapKeySet
 
getKeysFromRecords(Collection<Record>) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
getKeySize() - Method in class com.hazelcast.config.EncryptionAtRestConfig
Returns the size (in bits) of the Hot Restart Store-level encryption key.
getKeyStorageMemoryCost(K) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
getKeyStorageMemoryCost(K) - Method in class com.hazelcast.internal.nearcache.impl.store.NearCacheDataRecordStore
 
getKeyStorageMemoryCost(K) - Method in class com.hazelcast.internal.nearcache.impl.store.NearCacheObjectRecordStore
 
getKeyType() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
 
getKeyType() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getKeyType() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the key type for this ICache.
getKubernetesConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the current KubernetesConfig.
getKubernetesConfig() - Method in class com.hazelcast.config.JoinConfig
 
getKubernetesConfig() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the KubernetesConfig used by the discovery mechanism for this WAN publisher.
getLabel() - Method in class com.hazelcast.spi.impl.merge.AbstractContainerMerger
Returns a label of the service for customized error messages.
getLabels() - Method in interface com.hazelcast.client.Client
 
getLabels() - Method in class com.hazelcast.client.config.ClientConfig
 
getLabels() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
getLabels() - Method in class com.hazelcast.client.impl.ClientEvent
 
getLabels() - Method in class com.hazelcast.client.impl.ClientImpl
 
getLanguageName() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
 
getLanguageVersion() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
 
getLargestSequence() - Method in class com.hazelcast.ringbuffer.impl.RingbufferStoreWrapper
 
getLargestSequence() - Method in interface com.hazelcast.ringbuffer.RingbufferStore
Return the largest sequence seen by the data store.
getLastAccessTime() - Method in interface com.hazelcast.cache.CacheEntryView
Gets the last access time in milliseconds of the cache entry.
getLastAccessTime() - Method in interface com.hazelcast.cache.CacheStatistics
Gets the last access time to cache.
getLastAccessTime() - Method in class com.hazelcast.cache.impl.CacheEventContext
 
getLastAccessTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
getLastAccessTime() - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
 
getLastAccessTime() - Method in class com.hazelcast.cache.impl.merge.entry.LazyCacheEntryView
 
getLastAccessTime() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
getLastAccessTime() - Method in interface com.hazelcast.core.EntryView
Returns the last access time for the entry.
getLastAccessTime() - Method in interface com.hazelcast.internal.eviction.Evictable
Gets the latest access time difference of this Evictable in milliseconds.
getLastAccessTime() - Method in interface com.hazelcast.internal.eviction.EvictableEntryView
Gets the latest access time difference of this EvictableEntryView in milliseconds.
getLastAccessTime() - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.CacheBrowserEntryView
 
getLastAccessTime() - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
getLastAccessTime() - Method in class com.hazelcast.internal.nearcache.impl.store.HeapNearCacheRecordMap.NearCacheEvictableSamplingEntry
 
getLastAccessTime() - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
getLastAccessTime() - Method in interface com.hazelcast.map.impl.record.Record
 
getLastAccessTime() - Method in class com.hazelcast.map.impl.record.RecordInfo
 
getLastAccessTime() - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
 
getLastAccessTime() - Method in class com.hazelcast.map.impl.SimpleEntryView
 
getLastAccessTime() - Method in class com.hazelcast.map.impl.wan.WanMapEntryView
 
getLastAccessTime() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
getLastAccessTime() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
 
getLastAccessTime() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
getLastAccessTime() - Method in class com.hazelcast.monitor.impl.LocalRecordStoreStatsImpl
 
getLastAccessTime() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
getLastAccessTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
Gets the last access time to cache.
getLastAccessTime() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the last access (read) time of the locally owned entries.
getLastAccessTime() - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Returns the last access (read) time of the locally owned entries of this partition.
getLastAccessTime() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
getLastAccessTime() - Method in class com.hazelcast.multimap.impl.MultiMapMergeContainer
 
getLastAccessTime() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
getLastAccessTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
getLastAccessTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
getLastAccessTime() - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
getLastAccessTime() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
getLastAccessTime() - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
getLastAccessTime() - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
getLastAccessTime() - Method in interface com.hazelcast.spi.merge.MergingLastAccessTime
Returns the last access time of the merge data.
getLastCallId() - Method in class com.hazelcast.spi.impl.sequence.AbstractCallIdSequence
 
getLastCallId() - Method in interface com.hazelcast.spi.impl.sequence.CallIdSequence
Returns the last issued call ID.
getLastCallId() - Method in class com.hazelcast.spi.impl.sequence.CallIdSequenceWithoutBackpressure
 
getLastCheckedLeafCount() - Method in class com.hazelcast.wan.ConsistencyCheckResult
 
getLastCheckedPartitionCount() - Method in class com.hazelcast.wan.ConsistencyCheckResult
 
getLastChild() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getLastCleanupTime() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
 
getLastCleanupTime(CachePartitionSegment) - Method in class com.hazelcast.cache.impl.eviction.CacheClearExpiredRecordsTask
 
getLastCleanupTime(T) - Method in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
getLastCleanupTime(PartitionContainer) - Method in class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
 
getLastCleanupTime() - Method in class com.hazelcast.map.impl.PartitionContainer
 
getLastCleanupTimeBeforeSorting() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
 
getLastCleanupTimeCopy() - Method in class com.hazelcast.map.impl.PartitionContainer
 
getLastConsistencyCheckResults() - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
getLastConsistencyCheckResults() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the last results of the consistency checks, mapped by map name.
getLastCredentials() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
getLastDiffLeafCount() - Method in class com.hazelcast.wan.ConsistencyCheckResult
 
getLastDiffPartitionCount() - Method in class com.hazelcast.wan.ConsistencyCheckResult
 
getLastEntriesToSync() - Method in class com.hazelcast.wan.ConsistencyCheckResult
 
getLastHeartbeatTime(Member) - Method in class com.hazelcast.internal.cluster.impl.ClusterHeartbeatManager
 
getLastIdleTime(TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskStatisticsImpl
 
getLastIdleTime(TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
Returns the last period of time the task was idle, waiting to get scheduled
getLastPersistenceDuration() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
getLastPersistenceDuration() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the duration in milliseconds of the last Near Cache key persistence (when the pre-load feature is enabled).
getLastPersistenceFailure() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
getLastPersistenceFailure() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the failure reason of the last Near Cache persistence (when the pre-load feature is enabled).
getLastPersistenceKeyCount() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
getLastPersistenceKeyCount() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the number of persisted keys of the last Near Cache key persistence (when the pre-load feature is enabled).
getLastPersistenceTime() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
getLastPersistenceTime() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the timestamp of the last Near Cache key persistence (when the pre-load feature is enabled).
getLastPersistenceWrittenBytes() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
getLastPersistenceWrittenBytes() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the written bytes of the last Near Cache key persistence (when the pre-load feature is enabled).
getLastRepartitionTime() - Method in class com.hazelcast.internal.partition.impl.MigrationStats
Returns the last repartition time.
getLastRunDuration(TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskStatisticsImpl
 
getLastRunDuration(TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
Returns the duration of the task's last execution.
getLastStoredTime() - Method in interface com.hazelcast.core.EntryView
Returns the last time the value was flushed to its store (e.g.
getLastStoredTime() - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
getLastStoredTime() - Method in interface com.hazelcast.map.impl.record.Record
 
getLastStoredTime() - Method in class com.hazelcast.map.impl.record.RecordInfo
 
getLastStoredTime() - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
 
getLastStoredTime() - Method in class com.hazelcast.map.impl.SimpleEntryView
 
getLastStoredTime() - Method in class com.hazelcast.map.impl.wan.WanMapEntryView
 
getLastStoredTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
getLastStoredTime() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
getLastStoredTime() - Method in interface com.hazelcast.spi.merge.MergingLastStoredTime
Returns the last stored time of the merge data.
getLastSyncStats() - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
getLastSyncStats() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the last synchronization statistics, mapped by map name.
getLastUpdateTime() - Method in interface com.hazelcast.cache.CacheStatistics
Gets the last update time to cache.
getLastUpdateTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
getLastUpdateTime() - Method in interface com.hazelcast.core.EntryView
Returns the last time the value was updated.
getLastUpdateTime() - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
getLastUpdateTime() - Method in interface com.hazelcast.map.impl.record.Record
 
getLastUpdateTime() - Method in class com.hazelcast.map.impl.record.RecordInfo
 
getLastUpdateTime() - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
 
getLastUpdateTime() - Method in class com.hazelcast.map.impl.SimpleEntryView
 
getLastUpdateTime() - Method in class com.hazelcast.map.impl.wan.WanMapEntryView
 
getLastUpdateTime() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
getLastUpdateTime() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
 
getLastUpdateTime() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
getLastUpdateTime() - Method in class com.hazelcast.monitor.impl.LocalRecordStoreStatsImpl
 
getLastUpdateTime() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
getLastUpdateTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
Gets the last update time to cache.
getLastUpdateTime() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the last update time of the locally owned entries.
getLastUpdateTime() - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Returns the last update time of the locally owned entries of this partition.
getLastUpdateTime() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
getLastUpdateTime() - Method in class com.hazelcast.multimap.impl.MultiMapMergeContainer
 
getLastUpdateTime() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
getLastUpdateTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
getLastUpdateTime() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
getLastUpdateTime() - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
getLastUpdateTime() - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
getLastUpdateTime() - Method in interface com.hazelcast.spi.merge.MergingLastUpdateTime
Returns the last update time of the merge data.
getLdapAuthenticationConfig() - Method in class com.hazelcast.config.security.RealmConfig
 
getLeadedGroups() - Method in class com.hazelcast.cp.internal.RaftService
 
GetLeadedGroupsOp - Class in com.hazelcast.cp.internal.operation
Returns the CP groups that this local CP member is the Raft group leader.
GetLeadedGroupsOp() - Constructor for class com.hazelcast.cp.internal.operation.GetLeadedGroupsOp
 
getLeader() - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Returns the known leader endpoint.
getLeader() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
getLeaderElectionTimeoutInMillis() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getLeaderElectionTimeoutInMillis() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Returns a randomized leader election timeout in milliseconds based on configured timeout.
getLeaderHeartbeatPeriodInMillis() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getLeaderUuid() - Method in exception com.hazelcast.cp.exception.CPSubsystemException
Returns the leader endpoint of related CP group, if known/available by the time this exception is thrown.
getLeftChildOrder(int) - Static method in class com.hazelcast.wan.impl.merkletree.MerkleTreeUtil
Returns the breadth-first order of the left child node of the node with nodeOrder
getLength() - Method in class com.hazelcast.internal.partition.PartitionTableView
 
getLevel() - Method in interface com.hazelcast.logging.ILogger
Gets the logging level.
getLevel() - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
getLevelOfNode(int) - Static method in class com.hazelcast.wan.impl.merkletree.MerkleTreeUtil
Returns the level a node with the given order is on in the tree
getLicenseKey() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getLicenseKey() - Method in class com.hazelcast.config.Config
Returns the license key for this hazelcast instance.
getLicenseKey() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getLifecycleMutexFactory() - Method in class com.hazelcast.client.impl.querycache.ClientQueryCacheContext
 
getLifecycleMutexFactory() - Method in class com.hazelcast.map.impl.querycache.NodeQueryCacheContext
 
getLifecycleMutexFactory() - Method in interface com.hazelcast.map.impl.querycache.QueryCacheContext
 
getLifecycleService() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getLifecycleService() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getLifecycleService() - Method in class com.hazelcast.client.impl.spi.ClientContext
 
getLifecycleService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the lifecycle service for this instance.
getLifecycleService() - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getLifecycleService() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getLifeStartTime(Record) - Static method in class com.hazelcast.map.impl.ExpirationTimeSetter
Returns last-update-time of an entry if it was updated before, otherwise it returns creation-time of the entry.
getLine() - Method in exception com.hazelcast.internal.json.ParseException
Deprecated.
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.clientside.HazelcastClientInstanceImpl
 
getList(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getList(String) - Method in class com.hazelcast.client.impl.proxy.txn.TransactionContextProxy
 
getList(String) - Method in class com.hazelcast.client.impl.proxy.txn.xa.XATransactionContextProxy
 
getList() - Method in class com.hazelcast.console.ConsoleApp
 
getList(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed list instance with the specified name.
getList(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getList(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getList() - Method in class com.hazelcast.internal.util.collection.WeightedEvictableList
 
getList(String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
 
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.client.impl.clientside.ClientDynamicClusterConfig
 
getListConfig(String) - Method in class com.hazelcast.config.Config
Returns the ListConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getListConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getListConfigs() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getListConfigs() - Method in class com.hazelcast.config.Config
Returns the map of IList configurations, mapped by config name.
getListConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
getListConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Returns all registered list configurations.
getListConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getListener() - Method in class com.hazelcast.cache.impl.CacheEventListenerAdaptor
 
getListener() - Method in interface com.hazelcast.internal.services.ListenerWrapperEventFilter
Gets the wrapped listener.
getListener() - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRequest
 
getListener() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
 
getListenerAdapter() - Method in class com.hazelcast.client.impl.querycache.subscriber.ListenerInfo
 
getListenerAdapters() - Method in class com.hazelcast.map.impl.InternalMapListenerAdapter
 
getListenerConfigs() - Method in class com.hazelcast.client.config.ClientConfig
Gets list of all configured ListenerConfig's
getListenerConfigs() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getListenerConfigs() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
getListenerConfigs() - Method in class com.hazelcast.config.Config
Returns the list of EventListener configurations.
getListenerConfigs() - Method in class com.hazelcast.config.ReplicatedMapConfig
 
getListenerConfigs() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
getListenerConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getListenerConfigurations() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
getListenerConfigurations() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getListenerId(CacheEntryListenerConfiguration) - Method in class com.hazelcast.cache.impl.AbstractCacheSyncListenerCompleter
 
getListenerImplementation() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.ListenerConfigHolder
 
getListenerRegistrator() - Method in class com.hazelcast.map.impl.querycache.publisher.DefaultPublisherContext
 
getListenerRegistrator() - Method in interface com.hazelcast.map.impl.querycache.publisher.PublisherContext
Returns a helper function in order to register listener to IMap
getListenerService() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getListenerService() - Method in class com.hazelcast.client.impl.spi.ClientContext
 
getListenersIds(boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheSyncListenerCompleter
 
getListenerType() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.ListenerConfigHolder
 
getLiveOperationRegistry() - Method in class com.hazelcast.internal.metrics.impl.MetricsService
 
getLiveOperations(CPGroupId) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
getLiveOperations() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
getLoadBalancer() - Method in class com.hazelcast.client.config.ClientConfig
Gets LoadBalancer
getLoadBalancer() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getLocalAddress() - Method in class com.hazelcast.internal.cluster.impl.BindMessage
 
getLocalAddresses() - Method in class com.hazelcast.internal.cluster.impl.ExtendedBindMessage
 
getLocalAvgAge() - Method in class com.hazelcast.internal.jmx.QueueMBean
 
getLocalBackupCount() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalBackupCount() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalBackupEntryCount() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalBackupEntryCount() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalBackupEntryMemoryCost() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalBackupEntryMemoryCost() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalBackupItemCount() - Method in class com.hazelcast.internal.jmx.QueueMBean
 
getLocalCacheStatistics() - Method in interface com.hazelcast.cache.ICache
Directly access local Cache Statistics.
getLocalCacheStatistics() - Method in class com.hazelcast.cache.impl.CacheProxy
 
getLocalCacheStatistics() - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
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.internal.jmx.ExecutorServiceMBean
 
getLocalClient() - Method in interface com.hazelcast.client.impl.spi.ClientClusterService
 
getLocalClient() - Method in class com.hazelcast.client.impl.spi.impl.ClientClusterServiceImpl
 
getLocalClientUuids() - Method in interface com.hazelcast.client.impl.ClientEndpointManager
Gets all the endpoints for a given client.
getLocalClientUuids() - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
 
getLocalCompletedTaskCount() - Method in class com.hazelcast.internal.jmx.ExecutorServiceMBean
 
getLocalCPEndpoint() - Method in class com.hazelcast.cp.internal.RaftService
 
getLocalCPMember() - Method in class com.hazelcast.client.cp.internal.CPSubsystemImpl
 
getLocalCPMember() - Method in interface com.hazelcast.cp.CPSubsystem
Returns the local CP member if this Hazelcast member is part of CP Subsystem, returns null otherwise.
getLocalCPMember() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Returns the local CP member if this Hazelcast member is part of CP Subsystem, returns null otherwise.
getLocalCPMember() - Method in class com.hazelcast.cp.internal.CPSubsystemImpl
 
getLocalCPMember() - Method in class com.hazelcast.cp.internal.RaftService
 
getLocalCreationTime() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalCreationTime() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalCreationTime() - Method in class com.hazelcast.internal.jmx.ReliableTopicMBean
 
getLocalCreationTime() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
getLocalCreationTime() - Method in class com.hazelcast.internal.jmx.TopicMBean
 
getLocalDirtyEntryCount() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalDirtyEntryCount() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalEmptyPollOperationCount() - Method in class com.hazelcast.internal.jmx.QueueMBean
 
getLocalEndpoint() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getLocalEndpoint() - Method in class com.hazelcast.client.impl.clientside.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.impl.HazelcastInstanceImpl
 
getLocalEndpoint() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getLocalEventOperationCount() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalEventOperationCount() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalEventOperationCount() - Method in class com.hazelcast.internal.jmx.QueueMBean
 
getLocalEventOperationCount() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
getLocalExecutorStats() - Method in class com.hazelcast.client.impl.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
 
getLocalFlakeIdGeneratorStats(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
getLocalFlakeIdGeneratorStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalGetOperationCount() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalGetOperationCount() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalGetOperationCount() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
getLocalHits() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalHits() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalHits() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
getLocalLastAccessTime() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalLastAccessTime() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalLastAccessTime() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
getLocalLastUpdateTime() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalLastUpdateTime() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalLastUpdateTime() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
getLocalLockedEntryCount() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalLockedEntryCount() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalMapStats() - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
getLocalMapStats() - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
getLocalMapStats() - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
getLocalMapStats() - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
getLocalMapStats() - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
getLocalMapStats() - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
getLocalMapStats() - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
getLocalMapStats() - Method in interface com.hazelcast.map.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.internal.jmx.QueueMBean
 
getLocalMaxGetLatency() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalMaxGetLatency() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalMaxGetLatency() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
getLocalMaxPutLatency() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalMaxPutLatency() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalMaxPutLatency() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
getLocalMaxSetLatency() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalMember() - Method in class com.hazelcast.client.impl.proxy.ClientClusterProxy
 
getLocalMember() - Method in interface com.hazelcast.cluster.Cluster
Returns this Hazelcast instance member.
getLocalMember() - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Returns the Raft endpoint for this node.
getLocalMember() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
getLocalMember() - Method in class com.hazelcast.instance.impl.Node
 
getLocalMember() - Method in interface com.hazelcast.internal.cluster.ClusterService
Gets the local member instance.
getLocalMember() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getLocalMember() - Method in interface com.hazelcast.spi.impl.NodeEngine
Returns the local member.
getLocalMember() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getLocalMemoryStats() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
getLocalMemoryStats() - Method in interface com.hazelcast.monitor.MemberState
 
getLocalMinAge() - Method in class com.hazelcast.internal.jmx.QueueMBean
 
getLocalMultiMapStats() - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
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
 
getLocalMultiMapStats() - Method in interface com.hazelcast.multimap.MultiMap
Returns LocalMultiMapStats for this map.
getLocalMultiMapStatsImpl(String) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
getLocalName() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getLocalOfferOperationCount() - Method in class com.hazelcast.internal.jmx.QueueMBean
 
getLocalOtherOperationCount() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalOtherOperationCount() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalOtherOperationCount() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
getLocalOtherOperationsCount() - Method in class com.hazelcast.internal.jmx.QueueMBean
 
getLocalOwnedEntryCount() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalOwnedEntryCount() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalOwnedEntryCount() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
getLocalOwnedEntryMemoryCost() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalOwnedEntryMemoryCost() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalOwnedItemCount() - Method in class com.hazelcast.internal.jmx.QueueMBean
 
getLocalPendingTaskCount() - Method in class com.hazelcast.internal.jmx.ExecutorServiceMBean
 
getLocalPNCounterStats(String) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterService
Returns the PN counter statistics for the counter with the given name
getLocalPNCounterStats(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
getLocalPNCounterStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalPollOperationCount() - Method in class com.hazelcast.internal.jmx.QueueMBean
 
getLocalPublishOperationCount() - Method in class com.hazelcast.internal.jmx.ReliableTopicMBean
 
getLocalPublishOperationCount() - Method in class com.hazelcast.internal.jmx.TopicMBean
 
getLocalPutOperationCount() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalPutOperationCount() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalPutOperationCount() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
getLocalQueueStats() - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
getLocalQueueStats() - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
getLocalQueueStats() - Method in interface com.hazelcast.collection.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.internal.jmx.ReliableTopicMBean
 
getLocalReceiveOperationCount() - Method in class com.hazelcast.internal.jmx.TopicMBean
 
getLocalRecordStoreStats() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
getLocalRejectedOfferOperationCount() - Method in class com.hazelcast.internal.jmx.QueueMBean
 
getLocalRemoveOperationCount() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalRemoveOperationCount() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalRemoveOperationCount() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
getLocalReplicatedMapStats(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
getLocalReplicatedMapStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocalReplicatedMapStats(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
Gets the replicated map's local statistics.
getLocalReplicatedMapStatsImpl(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
Gets the LocalReplicatedMapStatsImpl implementation of LocalReplicatedMapStats for the provided of the replicated map.
getLocalSetOperationCount() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalSocketAddress() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
getLocalStartedTaskCount() - Method in class com.hazelcast.internal.jmx.ExecutorServiceMBean
 
getLocalStats() - Method in class com.hazelcast.internal.jmx.LocalStatsDelegate
 
getLocalTopicStats() - Method in class com.hazelcast.client.impl.proxy.ClientReliableTopicProxy
 
getLocalTopicStats() - Method in class com.hazelcast.client.impl.proxy.ClientTopicProxy
 
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(String) - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicService
Returns reliable topic statistics local to this member for the reliable topic with name.
getLocalTopicStats() - Method in class com.hazelcast.topic.impl.TopicProxy
 
getLocalTopicStats(String) - Method in class com.hazelcast.topic.impl.TopicService
 
getLocalTopicStats() - Method in interface com.hazelcast.topic.ITopic
Returns statistics about this topic, like total number of publishes/receives.
getLocalTopicStatsInternal() - Method in class com.hazelcast.topic.impl.TopicProxySupport
 
getLocalTotalExecutionLatency() - Method in class com.hazelcast.internal.jmx.ExecutorServiceMBean
 
getLocalTotalGetLatency() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalTotalGetLatency() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalTotalGetLatency() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
getLocalTotalPutLatency() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalTotalPutLatency() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalTotalPutLatency() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
getLocalTotalRemoveLatency() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalTotalRemoveLatency() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getLocalTotalRemoveLatency() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
getLocalTotalSetLatency() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getLocalTotalStartLatency() - Method in class com.hazelcast.internal.jmx.ExecutorServiceMBean
 
getLocalUpdatePolicy() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.NearCacheConfigHolder
 
getLocalUpdatePolicy() - Method in class com.hazelcast.config.NearCacheConfig
Returns the NearCacheConfig.LocalUpdatePolicy of this Near Cache.
getLocalWanPublisherStats() - Method in class com.hazelcast.monitor.impl.LocalWanStatsImpl
 
getLocalWanPublisherStats() - Method in interface com.hazelcast.monitor.LocalWanStats
Returns the statistics of different publisher clusters belongs the scheme on this member
getLocalWanStats(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
getLocalWanStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getLocation() - Method in class com.hazelcast.internal.json.JsonHandler
Returns the current parser location.
getLocation() - Method in exception com.hazelcast.internal.json.ParseException
Returns the location at which the error occurred.
getLock(String) - Method in class com.hazelcast.client.cp.internal.CPSubsystemImpl
 
getLock(String) - Method in interface com.hazelcast.cp.CPSubsystem
Returns a proxy for an FencedLock instance created on CP Subsystem.
getLock(String) - Method in class com.hazelcast.cp.internal.CPSubsystemImpl
 
getLock(Data) - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
getLockAcquireLimit() - Method in class com.hazelcast.config.cp.FencedLockConfig
Returns the maximum number of lock acquires a lock holder can perform.
getLockConfigs() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the map of FencedLock configurations
getLockContainer(int) - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
getLockCount() - Method in class com.hazelcast.client.cp.internal.datastructures.lock.FencedLockProxy
 
getLockCount() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockOwnershipState
 
getLockCount() - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
getLockCount() - Method in interface com.hazelcast.cp.lock.FencedLock
Returns the reentrant lock count if the lock is held by any thread in the cluster.
getLockCount() - Method in interface com.hazelcast.internal.locksupport.LockResource
 
getLockCount(Data) - Method in interface com.hazelcast.internal.locksupport.LockStore
Return the number of times a key was locked by the same owner (re-entered).
getLockCount(Data) - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
getLockCount(Data) - Method in class com.hazelcast.internal.locksupport.LockStoreProxy
 
getLockedCount() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
getLockedEntryCount() - Method in interface com.hazelcast.internal.locksupport.LockStore
Return the number of locks this store holds.
getLockedEntryCount() - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
getLockedEntryCount() - Method in class com.hazelcast.internal.locksupport.LockStoreProxy
 
getLockedEntryCount() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
getLockedEntryCount() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
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 keys.
getLockedKeys() - Method in interface com.hazelcast.internal.locksupport.LockStore
Return all locked keys for this store.
getLockedKeys() - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
getLockedKeys() - Method in class com.hazelcast.internal.locksupport.LockStoreProxy
 
getLockedSessionId(long) - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
getLockExpiryTime() - Method in class com.hazelcast.internal.util.LockGuard
 
getLockOwner() - Method in class com.hazelcast.internal.util.LockGuard
 
getLockOwnerId() - Method in class com.hazelcast.internal.util.LockGuard
 
getLockOwnerInfo(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
getLockOwnerInfo(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
getLockOwnerInfo(Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
getLockOwnershipState(CPGroupId, String) - Method in class com.hazelcast.cp.internal.datastructures.lock.LockService
 
GetLockOwnershipStateMessageTask - Class in com.hazelcast.cp.internal.datastructures.lock.client
Client message task for GetLockOwnershipStateOp
GetLockOwnershipStateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.lock.client.GetLockOwnershipStateMessageTask
 
GetLockOwnershipStateOp - Class in com.hazelcast.cp.internal.datastructures.lock.operation
 
GetLockOwnershipStateOp() - Constructor for class com.hazelcast.cp.internal.datastructures.lock.operation.GetLockOwnershipStateOp
 
GetLockOwnershipStateOp(String) - Constructor for class com.hazelcast.cp.internal.datastructures.lock.operation.GetLockOwnershipStateOp
 
getLockReferenceIdGenerator() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getLocks() - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
getLockStore(ObjectNamespace) - Method in class com.hazelcast.internal.locksupport.LockStoreContainer
 
getLockStore(int, ObjectNamespace) - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
getLockStore() - Method in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
getLockStores() - Method in class com.hazelcast.internal.locksupport.LockStoreContainer
 
getLogEntry(long) - Method in class com.hazelcast.cp.internal.raft.impl.log.RaftLog
Returns the log entry stored at entryIndex.
getLogger(Class) - Method in interface com.hazelcast.client.impl.ClientEngine
 
getLogger(Class) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
getLogger(String) - Method in class com.hazelcast.client.impl.clientside.ClientLoggingService
 
getLogger(Class) - Method in class com.hazelcast.client.impl.clientside.ClientLoggingService
 
getLogger() - Method in class com.hazelcast.client.impl.MemberImpl
 
getLogger(Class) - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
getLogger() - Method in class com.hazelcast.cluster.impl.AbstractMember
 
getLogger() - Method in class com.hazelcast.cluster.impl.MemberImpl
 
getLogger(String) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Returns an ILogger instance for given name.
getLogger(Class) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
getLogger() - Method in class com.hazelcast.cp.internal.RaftOp
 
getLogger(String) - Method in class com.hazelcast.instance.impl.Node
 
getLogger(Class) - Method in class com.hazelcast.instance.impl.Node
 
getLogger(String) - Method in class com.hazelcast.logging.impl.LoggingServiceImpl
 
getLogger(Class) - Method in class com.hazelcast.logging.impl.LoggingServiceImpl
 
getLogger(Class) - Static method in class com.hazelcast.logging.Logger
Obtains a logger for the given clazz.
getLogger(String) - Static method in class com.hazelcast.logging.Logger
Obtains a logger of the given name.
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.NoLogFactory
 
getLogger(Class) - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
 
getLogger() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
Returns a ILogger instance bound to the current class.
getLogger() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
getLogger(String) - Method in interface com.hazelcast.spi.impl.NodeEngine
Gets the logger for a given name.
getLogger(Class) - Method in interface com.hazelcast.spi.impl.NodeEngine
Gets the logger for a given class.
getLogger(String) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getLogger(Class) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getLogger() - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
getLoggingService() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getLoggingService() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getLoggingService() - Method in class com.hazelcast.client.impl.spi.ClientContext
 
getLoggingService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the logging service of this Hazelcast instance.
getLoggingService() - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getLoggingService() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getLoggingService() - Method in class com.hazelcast.instance.impl.Node
 
getLoggingService() - Method in interface com.hazelcast.internal.nio.IOService
 
getLoggingService() - Method in class com.hazelcast.internal.nio.NodeIOService
 
getLoggingService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getLoginModuleConfigs() - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
 
getLogRecord() - Method in class com.hazelcast.logging.LogEvent
 
getLong(String, long) - Method in class com.hazelcast.internal.json.JsonObject
Returns the long value of the member with the specified name in this object.
getLong(Object, long) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Returns the long value at the supplied offset from the supplied object's base address.
getLong(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getLong(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getLong(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getLong(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getLong(long) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Reads the long value from given address.
getLong(JsonObject, String) - Static method in class com.hazelcast.internal.util.JsonUtil
Returns a field in a Json object as a long.
getLong(JsonObject, String, long) - Static method in class com.hazelcast.internal.util.JsonUtil
Returns a field in a Json object as a long.
getLong(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured long value of a HazelcastProperty.
getLongContainer() - Method in class com.hazelcast.internal.longregister.operations.AbstractLongRegisterOperation
 
getLongRegister(String) - Method in class com.hazelcast.internal.longregister.LongRegisterService
 
getLongValue(String, String) - Static method in class com.hazelcast.config.DomConfigHelper
 
getLongValue(String, String, long) - Static method in class com.hazelcast.config.DomConfigHelper
 
getLongVolatile(Object, long) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Reads the long value as volatile from given object by its offset.
getLongVolatile(long) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Reads the long value as volatile from given object by its offset.
getLongVolatile(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getLongVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getLongVolatile(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getLongVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getLostBackupCount() - Method in class com.hazelcast.internal.partition.PartitionLostEventImpl
Returns the number of lost backups for the partition.
getLostBackupCount() - Method in interface 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.internal.partition.PartitionLostEventImpl
 
getLostReplicaIndex() - Method in interface com.hazelcast.spi.partition.IPartitionLostEvent
0-based replica index that is lost for the partition.
getMajor() - Method in class com.hazelcast.version.MemberVersion
 
getMajor() - Method in class com.hazelcast.version.Version
 
getMajorCollectionCount() - Method in class com.hazelcast.internal.memory.DefaultGarbageCollectorStats
 
getMajorCollectionCount() - Method in interface com.hazelcast.internal.memory.GarbageCollectorStats
Returns major collection count.
getMajorCollectionCount() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
 
getMajorCollectionTime() - Method in class com.hazelcast.internal.memory.DefaultGarbageCollectorStats
 
getMajorCollectionTime() - Method in interface com.hazelcast.internal.memory.GarbageCollectorStats
Returns total major collection time in ms.
getMajorCollectionTime() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
 
getMajorVersion() - Method in enum com.hazelcast.internal.util.JavaVersion
 
getManagedContext() - Method in class com.hazelcast.client.config.ClientConfig
getManagedContext() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getManagedContext() - Method in class com.hazelcast.config.Config
Returns the external managed context.
getManagedContext() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getManagedContext() - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
getManagedContext() - Method in interface com.hazelcast.internal.serialization.PortableContext
 
getManagedContext() - Method in interface com.hazelcast.internal.serialization.SerializationService
getManagedExecutorBean(String) - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
 
getManagementCenterConfig() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getManagementCenterConfig() - Method in class com.hazelcast.config.Config
Returns the management center configuration for this hazelcast instance.
getManagementCenterConfig() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getManagementCenterConnectionFactory() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
getManagementCenterConnectionFactory() - Method in interface com.hazelcast.instance.impl.NodeExtension
 
getManagementCenterService() - Method in class com.hazelcast.instance.impl.Node
 
getManagementCenterService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getManagementService() - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getManagerPrefix() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
getManagerPrefix() - Method in class com.hazelcast.config.CacheConfig
Gets the manager prefix of the ICache, such as "hz://".
getMap() - Method in class com.hazelcast.client.console.ClientConsoleApp
 
getMap(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getMap(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getMap(String) - Method in class com.hazelcast.client.impl.proxy.txn.TransactionContextProxy
 
getMap(String) - Method in class com.hazelcast.client.impl.proxy.txn.xa.XATransactionContextProxy
 
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
Creates or returns the distributed map instance with the specified name.
getMap(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getMap(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getMap() - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
getMap() - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRequest
 
getMap(String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
 
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.
getMapConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getMapConfig(String) - Method in class com.hazelcast.config.Config
Returns the MapConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getMapConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getMapConfig() - Method in class com.hazelcast.map.impl.MapContainer
 
GetMapConfigOperation - Class in com.hazelcast.internal.management.operation
Operation to fetch Map configuration.
GetMapConfigOperation(String) - Constructor for class com.hazelcast.internal.management.operation.GetMapConfigOperation
 
getMapConfigOrNull(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getMapConfigOrNull(String) - Method in class com.hazelcast.config.Config
Returns the map config with the given name or null if there is none.
getMapConfigOrNull(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getMapConfigs() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getMapConfigs() - Method in class com.hazelcast.config.Config
Returns the map of IMap configurations, mapped by config name.
getMapConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
getMapConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Returns all registered map configurations.
getMapConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getMapContainer(String) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getMapContainer() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
getMapContainers() - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getMapDataStore(String, int) - Method in interface com.hazelcast.map.impl.mapstore.MapStoreManager
 
getMapDataStore(String, int) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindManager
 
getMapDataStore(String, int) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughManager
 
getMapDataStore() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
getMapDataStore() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
GetMapEntryRequest - Class in com.hazelcast.internal.management.request
Request for fetching map entries.
GetMapEntryRequest() - Constructor for class com.hazelcast.internal.management.request.GetMapEntryRequest
 
GetMapEntryRequest(String, String, String) - Constructor for class com.hazelcast.internal.management.request.GetMapEntryRequest
 
getMapEventPublisher() - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getMapEvictionPolicy() - Method in class com.hazelcast.config.MapConfig
Returns custom eviction policy if it is set otherwise returns null.
getMapEvictionPolicy() - Method in class com.hazelcast.map.impl.MapContainer
 
getMapListener() - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
getMapListenerRegistry() - Method in class com.hazelcast.map.impl.querycache.publisher.DefaultPublisherContext
 
getMapListenerRegistry() - Method in interface com.hazelcast.map.impl.querycache.publisher.PublisherContext
Returns MapListenerRegistry for this context.
getMapName() - Method in class com.hazelcast.internal.ascii.memcache.MapNameAndKeyPair
 
getMapName() - Method in interface com.hazelcast.map.impl.event.EventData
 
getMapName() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
 
getMapName() - Method in class com.hazelcast.map.impl.query.Query
 
getMapName() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
 
getMapName() - Method in class com.hazelcast.map.impl.querycache.event.BatchEventData
 
getMapName() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
getMapName() - Method in class com.hazelcast.map.impl.querycache.event.LocalCacheWideEventData
 
getMapName() - Method in class com.hazelcast.map.impl.querycache.event.LocalEntryEventData
 
getMapName() - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRequest
 
getMapName() - Method in class com.hazelcast.query.impl.MapIndexInfo
 
getMapNearCacheManager() - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getMapOperationProvider(String) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getMapPublisherRegistry() - Method in class com.hazelcast.map.impl.querycache.publisher.DefaultPublisherContext
 
getMapPublisherRegistry() - Method in interface com.hazelcast.map.impl.querycache.publisher.PublisherContext
Returns MapPublisherRegistry for this context.
getMapQueryRunner(String) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
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.LocalMapStatsProvider
 
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
Returns a MapServiceContext implementation.
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.internal.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
 
getMapSubscriberRegistry() - Method in class com.hazelcast.map.impl.querycache.subscriber.AbstractSubscriberContext
 
getMapSubscriberRegistry() - Method in interface com.hazelcast.map.impl.querycache.subscriber.SubscriberContext
Returns MapSubscriberRegistry for this context.
getMaster() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
getMaster() - Method in class com.hazelcast.internal.partition.PartitionRuntimeState
 
getMasterAddress() - Method in interface com.hazelcast.client.impl.spi.ClientClusterService
Returns the address of the master member.
getMasterAddress() - Method in class com.hazelcast.client.impl.spi.impl.ClientClusterServiceImpl
 
getMasterAddress() - Method in class com.hazelcast.instance.impl.Node
 
getMasterAddress() - Method in interface com.hazelcast.internal.cluster.ClusterService
Returns the address of the master member.
getMasterAddress() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getMasterAddress() - Method in class com.hazelcast.internal.cluster.impl.MembersViewMetadata
 
getMasterAddress() - Method in class com.hazelcast.internal.cluster.impl.operations.MasterResponseOp
 
getMasterAddress() - Method in class com.hazelcast.internal.jmx.NodeMBean
 
getMasterAddress() - Method in interface com.hazelcast.spi.impl.NodeEngine
Gets the address of the master member.
getMasterAddress() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getMatchingIpv4Addresses(AddressUtil.AddressMatcher) - Static method in class com.hazelcast.internal.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.
getMaxAllowedBackupCount() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getMaxAllowedBackupCount() - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns maximum allowed backup count according to current cluster formation and partition group configuration.
getMaxAttempts() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
getMaxAttempts() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
getMaxBackoffMillis() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
When backoff reaches this upper bound, it does not increase any more.
getMaxConcurrentInvocations() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the maximum number of WAN event batches being sent to the target cluster concurrently.
getMaxConcurrentInvocations() - Method in class com.hazelcast.spi.impl.sequence.AbstractCallIdSequence
 
getMaxConcurrentInvocations() - Method in interface com.hazelcast.spi.impl.sequence.CallIdSequence
Returns the maximum concurrent invocations supported.
getMaxConcurrentInvocations() - Method in class com.hazelcast.spi.impl.sequence.CallIdSequenceWithoutBackpressure
 
getMaxConcurrentReplicationTargets() - Method in class com.hazelcast.config.CRDTReplicationConfig
Returns the maximum number of target members that we replicate the CRDT states to in one period.
getMaxGetLatency() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
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.internal.memory.DefaultMemoryStats
 
getMaxHeap() - Method in interface com.hazelcast.internal.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
 
getMaxIdle() - Method in interface com.hazelcast.core.EntryView
Returns the last set max idle time in milliseconds.
getMaxIdle() - Method in class com.hazelcast.map.impl.operation.PutIfAbsentOperation
 
getMaxIdle() - Method in class com.hazelcast.map.impl.operation.PutIfAbsentWithExpiryOperation
 
getMaxIdle() - Method in class com.hazelcast.map.impl.operation.PutOperation
 
getMaxIdle() - Method in class com.hazelcast.map.impl.operation.PutTransientOperation
 
getMaxIdle() - Method in class com.hazelcast.map.impl.operation.PutTransientWithExpiryOperation
 
getMaxIdle() - Method in class com.hazelcast.map.impl.operation.PutWithExpiryOperation
 
getMaxIdle() - Method in class com.hazelcast.map.impl.operation.SetOperation
 
getMaxIdle() - Method in class com.hazelcast.map.impl.operation.SetWithExpiryOperation
 
getMaxIdle() - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
getMaxIdle() - Method in interface com.hazelcast.map.impl.record.Record
 
getMaxIdle() - Method in class com.hazelcast.map.impl.record.RecordInfo
 
getMaxIdle() - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
 
getMaxIdle() - Method in class com.hazelcast.map.impl.SimpleEntryView
 
getMaxIdle() - Method in class com.hazelcast.map.impl.wan.WanMapEntryView
 
getMaxIdle() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
getMaxIdle() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
getMaxIdle() - Method in interface com.hazelcast.spi.merge.MergingMaxIdle
Returns the MaxIdle of the merge data.
getMaxIdleSeconds() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.NearCacheConfigHolder
 
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
Returns the maximum number of seconds each entry can stay in the Near Cache as untouched (not-read).
getMaximumPoolSize() - Method in class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
getMaximumPoolSize() - Method in interface com.hazelcast.internal.util.executor.ManagedExecutorService
 
getMaximumSizePolicy() - Method in class com.hazelcast.config.EvictionConfig
Returns the EvictionConfig.MaxSizePolicy of this eviction configuration.
getMaxJoinMillis() - Method in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
getMaxJoinTimeToMasterNode() - Method in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
getMaxLeaseTimeInMillis() - Method in interface com.hazelcast.internal.locksupport.LockSupportService
 
getMaxLeaseTimeInMillis() - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
getMaxLeaseTimeInMillis(HazelcastProperties) - Static method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
getMaxMemory() - Method in interface com.hazelcast.internal.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.internal.util.RuntimeMemoryInfoAccessor
 
getMaxMetadata() - Method in class com.hazelcast.internal.memory.DefaultMemoryStats
 
getMaxMetadata() - Method in interface com.hazelcast.internal.memory.MemoryStats
Returns the amount of native memory reserved for metadata.
getMaxMetadata() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
getMaxMissedLeaderHeartbeatCount() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getMaxNative() - Method in class com.hazelcast.internal.memory.DefaultMemoryStats
 
getMaxNative() - Method in interface com.hazelcast.internal.memory.MemoryStats
Returns the maximum amount of native memory that current HazelcastInstance will attempt to use in bytes.
getMaxNative() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
getMaxPutLatency() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
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.internal.jmx.MapMBean
 
getMaxRemoveLatency() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getMaxRemoveLatency() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
getMaxRemoveLatency() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
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.
getMaxSampleSize() - Method in class com.hazelcast.splitbrainprotection.impl.ProbabilisticSplitBrainProtectionFunction
 
getMaxSetLatency() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
getMaxSetLatency() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
getMaxSetLatency() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
getMaxSetLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the maximum latency of set operations.
getMaxSize() - Method in class com.hazelcast.config.CollectionConfig
Gets the maximum size for the Configuration.
getMaxSize() - Method in class com.hazelcast.config.QueueConfig
Returns the maximum size of the Queue.
getMaxSizeConfig() - Method in class com.hazelcast.config.MapConfig
 
getMaxSizeConfig() - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
getMaxSizePerNode(MaxSizeConfig) - Static method in class com.hazelcast.map.impl.MapKeyLoaderUtil
Returns the configured maximum entry count per node if the max size policy is MaxSizeConfig.MaxSizePolicy#PER_NODE and is not the default, otherwise returns -1.
getMaxSizePolicy() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.EvictionConfigHolder
 
getMaxSizePolicy() - Method in class com.hazelcast.config.MaxSizeConfig
Returns the maximum size policy of the map.
getMaxTargetEndpoints() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the maximum number of endpoints that WAN will connect to when using a discovery mechanism to define endpoints.
getMaxVisibleSlowOperationCount() - Method in class com.hazelcast.monitor.impl.LocalOperationStatsImpl
 
getMBeanInfo() - Method in class com.hazelcast.internal.jmx.HazelcastMBean
 
getMBeanInfo() - Method in class com.hazelcast.internal.metrics.jmx.MetricsMBean
 
getMBeanServerId() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
 
getMember() - Method in class com.hazelcast.cache.impl.CachePartitionEventData
 
getMember() - Method in class com.hazelcast.cache.impl.event.AbstractICacheEvent
Returns the member that fired this event.
getMember() - Method in interface com.hazelcast.cache.impl.event.ICacheEvent
Returns the member that fired this event.
getMember(ReliableTopicMessage) - Method in class com.hazelcast.client.impl.proxy.ClientReliableMessageRunner
 
getMember(Address) - Method in interface com.hazelcast.client.impl.spi.ClientClusterService
Gets the member for the given address.
getMember(UUID) - Method in interface com.hazelcast.client.impl.spi.ClientClusterService
Gets the member with the given UUID.
getMember(Address) - Method in class com.hazelcast.client.impl.spi.impl.ClientClusterServiceImpl
 
getMember(UUID) - Method in class com.hazelcast.client.impl.spi.impl.ClientClusterServiceImpl
 
getMember() - Method in class com.hazelcast.cluster.MembershipEvent
Returns the removed or added member.
getMember() - Method in class com.hazelcast.collection.ItemEvent
Returns the member that fired this event.
getMember() - Method in exception com.hazelcast.core.MemberLeftException
Returns the member that left the cluster
getMember() - Method in class com.hazelcast.cp.internal.raft.impl.command.UpdateRaftGroupMembersCmd
 
getMember() - Method in class com.hazelcast.cp.internal.raftop.metadata.AddCPMemberOp
 
getMember() - Method in class com.hazelcast.cp.internal.raftop.metadata.RemoveCPMemberOp
 
getMember(Address) - Method in interface com.hazelcast.internal.cluster.ClusterService
Gets the member for the given address.
getMember(UUID) - Method in interface com.hazelcast.internal.cluster.ClusterService
Gets the member with the given UUID.
getMember(Address, UUID) - Method in interface com.hazelcast.internal.cluster.ClusterService
Gets the member with the given UUID and address.
getMember(Address) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getMember(UUID) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getMember(Address, UUID) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getMember(Address) - Method in class com.hazelcast.internal.cluster.impl.MembershipManager
 
getMember(UUID) - Method in class com.hazelcast.internal.cluster.impl.MembershipManager
 
getMember(Address, UUID) - Method in class com.hazelcast.internal.cluster.impl.MembershipManager
 
getMember(Address) - Method in class com.hazelcast.internal.cluster.impl.MembersView
 
getMember() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidation
 
getMember() - Method in class com.hazelcast.internal.services.MembershipServiceEvent
Returns the removed or added member.
getMember() - Method in class com.hazelcast.logging.LogEvent
 
getMember() - Method in class com.hazelcast.map.AbstractIMapEvent
Returns the member that fired this event.
getMember() - Method in class com.hazelcast.map.EventLostEvent
 
getMember() - Method in interface com.hazelcast.map.IMapEvent
Returns the member that fired this event.
getMember() - Method in class com.hazelcast.map.impl.querycache.event.BatchIMapEvent
 
getMember() - Method in class com.hazelcast.map.impl.querycache.event.SingleIMapEvent
 
getMember(ReliableTopicMessage) - Method in class com.hazelcast.topic.impl.reliable.MessageRunner
 
getMember(ReliableTopicMessage) - Method in class com.hazelcast.topic.impl.reliable.ReliableMessageRunner
 
getMemberAddress() - Method in class com.hazelcast.internal.cluster.impl.MembersViewMetadata
 
getMemberAddresses() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getMemberAddresses() - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
 
getMemberAddresses() - Method in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
 
getMemberAddresses() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperation
 
getMemberAddressProviderConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
getMemberAddressProviderConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getMemberAddressProviderConfig() - Method in class com.hazelcast.config.NetworkConfig
 
getMemberAttributeConfig() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getMemberAttributeConfig() - Method in class com.hazelcast.config.Config
Returns the member attribute configuration.
getMemberAttributeConfig() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getMemberBuildInfo() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
getMemberCount() - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
 
getMemberCount() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getMemberGroupConfigs() - Method in class com.hazelcast.config.PartitionGroupConfig
Returns an unmodifiable collection containing all MemberGroupConfig elements.
getMemberGroups() - Method in interface com.hazelcast.spi.partitiongroup.PartitionGroupStrategy
 
getMemberGroupsSize() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getMemberGroupsSize() - Method in interface com.hazelcast.internal.partition.InternalPartitionService
Number of the member groups to be used in partition assignments.
getMemberHotRestartStatusMap() - Method in class com.hazelcast.internal.management.dto.ClusterHotRestartStatusDTO
 
getMemberImpls() - Method in interface com.hazelcast.internal.cluster.ClusterService
Gets the collection of members.
getMemberImpls() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getMemberList() - Method in class com.hazelcast.client.impl.querycache.ClientQueryCacheContext
 
getMemberList() - Method in interface com.hazelcast.client.impl.spi.ClientClusterService
Gets the collection of members.
getMemberList() - Method in class com.hazelcast.client.impl.spi.impl.ClientClusterServiceImpl
 
getMemberList() - Method in class com.hazelcast.internal.management.TimedMemberState
 
getMemberList() - Method in class com.hazelcast.map.impl.querycache.NodeQueryCacheContext
 
getMemberList() - Method in interface com.hazelcast.map.impl.querycache.QueryCacheContext
Returns member list of the cluster.
getMemberListJoinVersion() - Method in class com.hazelcast.cluster.impl.MemberImpl
 
getMemberListJoinVersion() - Method in interface com.hazelcast.internal.cluster.ClusterService
Returns the member list join version of the local member instance.
getMemberListJoinVersion() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getMemberListJoinVersion() - Method in class com.hazelcast.internal.cluster.MemberInfo
 
getMemberListString() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getMemberListVersion() - Method in interface com.hazelcast.internal.cluster.ClusterService
Returns the current version of member list.
getMemberListVersion() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getMemberListVersion() - Method in class com.hazelcast.internal.cluster.impl.MembershipManager
 
getMemberListVersion() - Method in class com.hazelcast.internal.cluster.impl.MembersViewMetadata
 
getMemberListVersion() - Method in class com.hazelcast.internal.cluster.impl.SplitBrainJoinMessage
 
getMemberPartitions(Address) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getMemberPartitions(Address) - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns partition ID list assigned to given target.
getMemberPartitionsIfAssigned(Address) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getMemberPartitionsIfAssigned(Address) - Method in interface com.hazelcast.internal.partition.InternalPartitionService
Returns partition ID list assigned to given target if partitions are assigned when method is called.
getMemberPartitionsMap() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getMemberPartitionsMap() - Method in interface com.hazelcast.spi.partition.IPartitionService
Gets member partition IDs.
getMemberPartitionState() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
getMemberPartitionState() - Method in interface com.hazelcast.monitor.MemberState
 
getMemberRealm() - Method in class com.hazelcast.config.SecurityConfig
 
getMemberRealm() - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
getMembers() - Method in class com.hazelcast.client.impl.proxy.ClientClusterProxy
 
getMembers(MemberSelector) - Method in interface com.hazelcast.client.impl.spi.ClientClusterService
Returns a collection of the members that satisfy the given MemberSelector.
getMembers(MemberSelector) - Method in class com.hazelcast.client.impl.spi.impl.ClientClusterServiceImpl
 
getMembers() - Method in class com.hazelcast.client.util.AbstractLoadBalancer
 
getMembers() - Method in interface com.hazelcast.cluster.Cluster
Set of the current members in the cluster.
getMembers() - Method in class com.hazelcast.cluster.InitialMembershipEvent
Returns an immutable set of ordered members at the moment this InitialMembershipListener is registered.
getMembers() - Method in class com.hazelcast.cluster.MembershipEvent
Returns a consistent view of the the members immediately after this MembershipEvent has been processed.
getMembers() - Method in class com.hazelcast.config.TcpIpConfig
Gets a list of all the well known members.
getMembers() - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
getMembers() - Method in exception com.hazelcast.cp.internal.raft.exception.MismatchingGroupMembersCommitIndexException
 
getMembers() - Method in class com.hazelcast.cp.internal.raft.impl.command.UpdateRaftGroupMembersCmd
 
getMembers(MemberSelector) - Method in interface com.hazelcast.internal.cluster.ClusterService
Returns a collection of the members that satisfy the given MemberSelector.
getMembers() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getMembers(MemberSelector) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getMembers() - Method in class com.hazelcast.internal.cluster.impl.MembershipManager
 
getMembers() - Method in class com.hazelcast.internal.cluster.impl.MembersView
 
getMembers() - Method in class com.hazelcast.internal.cluster.impl.TcpIpJoiner
 
getMembers() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getMembers() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
getMembersCommitIndex() - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
getMemberSet() - Method in class com.hazelcast.internal.cluster.impl.MembershipManager
 
getMembershipChangeSchedule() - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
getMembershipChangeSchedule() - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
GetMembershipChangeScheduleOp - Class in com.hazelcast.cp.internal.raftop.metadata
Returns the list of pending membership changes that will be orchestrated by the leader node of the Metadata group.
GetMembershipChangeScheduleOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.GetMembershipChangeScheduleOp
 
getMembershipManager() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getMemberState() - Method in class com.hazelcast.internal.management.TimedMemberState
 
getMembersView() - Method in class com.hazelcast.internal.cluster.impl.MembershipManager
 
GetMemberSystemPropertiesRequest - Class in com.hazelcast.internal.management.request
Request for fetching member system properties.
GetMemberSystemPropertiesRequest() - Constructor for class com.hazelcast.internal.management.request.GetMemberSystemPropertiesRequest
 
getMemberUuid() - Method in class com.hazelcast.internal.cluster.impl.MembersViewMetadata
 
getMemberVersion() - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
 
getMemberVersion() - Method in class com.hazelcast.monitor.impl.NodeStateImpl
 
getMemberVersion() - Method in interface com.hazelcast.monitor.NodeState
 
getMemcacheProtocolConfig() - Method in class com.hazelcast.config.NetworkConfig
 
getMemcacheProtocolConfig() - Method in interface com.hazelcast.internal.nio.IOService
Returns initialized MemcacheProtocolConfig for the node.
getMemcacheProtocolConfig() - Method in class com.hazelcast.internal.nio.NodeIOService
 
getMemoryCost() - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
getMemoryCost() - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
 
getMemoryCost() - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Returns the memory cost.
getMemoryCost() - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
getMemoryCost() - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Returns the memory cost of the index in bytes.
getMemoryCost() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the memory cost of the index in bytes.
getMemoryCostDelta() - Method in class com.hazelcast.monitor.impl.GlobalIndexOperationStats
 
getMemoryCostDelta() - Method in interface com.hazelcast.monitor.impl.IndexOperationStats
Returns the memory cost delta produced as a result of an index operation.
getMemoryCostDelta() - Method in class com.hazelcast.monitor.impl.PartitionIndexOperationStats
 
getMemoryFootprint() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.DenseHyperLogLogEncoder
 
getMemoryFootprint() - Method in interface com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogEncoder
Returns the size in memory occupied (in bytes) for this implementation of HyperLogLog.
getMemoryFootprint() - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.SparseHyperLogLogEncoder
 
getMemoryInfoAccessor() - Static method in class com.hazelcast.map.impl.MapContainer
 
getMemoryLimit() - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
 
getMemoryStats() - Method in interface com.hazelcast.client.impl.ClientExtension
Returns MemoryStats of for the JVM and current HazelcastInstance.
getMemoryStats() - Method in class com.hazelcast.client.impl.clientside.DefaultClientExtension
 
getMemoryStats() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
getMemoryStats() - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getMemoryStats() - Method in interface com.hazelcast.instance.impl.NodeExtension
Returns MemoryStats of for the JVM and current HazelcastInstance.
getMemoryStats() - Method in class com.hazelcast.internal.management.TimedMemberStateFactory
 
getMergePolicy(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
getMergePolicy() - Method in class com.hazelcast.config.WanReplicationRef
Returns the merge policy sent to the WAN replication target to merge replicated entries with existing target entries.
getMergePolicy() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
 
getMergePolicy(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
getMergePolicy(MergePolicyConfig) - Method in class com.hazelcast.spi.impl.merge.AbstractContainerMerger
Returns the SplitBrainMergePolicy instance of a given MergePolicyConfig.
getMergePolicy(String) - Method in class com.hazelcast.spi.impl.merge.AbstractMergeRunnable
 
getMergePolicy(String) - Method in class com.hazelcast.spi.merge.SplitBrainMergePolicyProvider
Resolves the SplitBrainMergePolicy class by its classname.
getMergePolicyConfig() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
getMergePolicyConfig() - Method in class com.hazelcast.config.AbstractBasicConfig
Gets the MergePolicyConfig of this data structure.
getMergePolicyConfig() - Method in class com.hazelcast.config.CacheConfig
Gets the MergePolicyConfig for this map.
getMergePolicyConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the MergePolicyConfig for this map.
getMergePolicyConfig() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Gets the MergePolicyConfig for the cardinality estimator.
getMergePolicyConfig() - Method in class com.hazelcast.config.CollectionConfig
Gets the MergePolicyConfig for the collection.
getMergePolicyConfig() - Method in class com.hazelcast.config.MapConfig
Gets the MergePolicyConfig for this map.
getMergePolicyConfig() - Method in class com.hazelcast.config.MultiMapConfig
Gets the MergePolicyConfig for this MultiMap.
getMergePolicyConfig() - Method in class com.hazelcast.config.QueueConfig
Gets the MergePolicyConfig for this queue.
getMergePolicyConfig() - Method in class com.hazelcast.config.ReplicatedMapConfig
Gets the MergePolicyConfig for this replicated map.
getMergePolicyConfig() - Method in class com.hazelcast.config.RingbufferConfig
Gets the MergePolicyConfig for this ringbuffer.
getMergePolicyConfig() - Method in class com.hazelcast.config.ScheduledExecutorConfig
Gets the MergePolicyConfig for the scheduler.
getMergePolicyConfig(C) - Method in class com.hazelcast.spi.impl.merge.AbstractContainerCollector
Returns the MergePolicyConfig of the container.
getMergePolicyProvider() - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
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
 
getMergingValueCount() - Method in class com.hazelcast.spi.impl.merge.AbstractContainerCollector
Returns the number of collected merging values in this collector.
getMergingValueData() - Method in class com.hazelcast.map.impl.DataAwareEntryEvent
 
getMerkleTreeConfig() - Method in class com.hazelcast.config.MapConfig
Gets the MerkleTreeConfig for this MapConfig
getMerkleTreeConfig() - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
getMerkleTreesCost() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
getMerkleTreesCost() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
getMerkleTreesCost() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
getMerkleTreesCost() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the heap cost of the Merkle trees
getMessage() - Method in class com.hazelcast.client.impl.protocol.exception.ErrorHolder
 
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.internal.config.TopicConfigReadOnly
 
getMessageObject() - Method in class com.hazelcast.topic.impl.DataAwareMessage
 
getMessageObject() - Method in class com.hazelcast.topic.Message
Returns the published message
GetMessageTask - Class in com.hazelcast.cp.internal.datastructures.atomiclong.client
Client message task for GetAndAddOp
GetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetMessageTask
 
GetMessageTask - Class in com.hazelcast.cp.internal.datastructures.atomicref.client
Client message task for GetOp
GetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.client.GetMessageTask
 
getMessageType() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
getMetadata() - Method in class com.hazelcast.map.impl.LazyMapEntry
 
getMetadata() - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
getMetadata() - Method in interface com.hazelcast.map.impl.record.Record
 
getMetadata(Record) - Method in class com.hazelcast.map.impl.recordstore.JsonMetadataRecordStoreMutationObserver
 
getMetadata() - Method in class com.hazelcast.query.impl.QueryableEntry
 
getMetaDataContainer(int) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingHandler
 
getMetaDataContainer(int) - Method in interface com.hazelcast.internal.nearcache.impl.invalidation.StaleReadDetector
 
getMetaDataContainer(int) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.StaleReadDetectorImpl
 
getMetadataFromRecord(RecordStore, Record) - Method in class com.hazelcast.map.impl.query.PartitionScanRunner
 
getMetaDataGenerator() - Method in class com.hazelcast.cache.impl.CacheEventHandler
 
getMetaDataGenerator() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
 
getMetadataGroupId() - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
getMetadataGroupId() - Method in class com.hazelcast.cp.internal.RaftService
 
getMetadataGroupManager() - Method in class com.hazelcast.cp.internal.RaftService
 
getMetadataPolicy() - Method in class com.hazelcast.config.MapConfig
Returns MetadataPolicy for this map.
getMetadataSpacePercentage() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns the percentage of native memory space to be used to store metadata and internal memory structures by the native memory manager.
getMethodCallSyntax(String, String, String...) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
 
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.AddBackupListenerMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionListenerMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
 
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.CacheAddNearCacheInvalidationListenerTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheContainsKeyMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheCreateConfigMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEntryProcessorMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalReadTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalSubscribeTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheFetchNearCacheInvalidationMetadataTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAllMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndRemoveMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetConfigMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateEntriesMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutAllMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutIfAbsentMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheReplaceMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSetExpiryPolicyMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.Pre38CacheAddInvalidationListenerTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorAddMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorEstimateMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.ClientStatisticsMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterAddMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetConfiguredReplicaCountMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxiesMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.DeployClassesMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddCacheConfigMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddCardinalityEstimatorConfigMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddDurableExecutorConfigMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddExecutorConfigMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddFlakeIdGeneratorConfigMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddListConfigMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddMapConfigMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddMultiMapConfigMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddQueueConfigMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddReliableTopicConfigMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddReplicatedMapConfigMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddRingbufferConfigMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddScheduledExecutorConfigMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddSetConfigMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddTopicConfigMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorDisposeResultMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorIsShutdownMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveAndDisposeResultMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveResultMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorShutdownMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorSubmitToPartitionMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnAddressMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnPartitionMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.IsFailoverSupportedMessageTask
 
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.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.MapAddListenerMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateWithPredicateMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsMessageTask
 
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.MapDestroyCacheMessageTask
 
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.MapEventJournalReadTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEventJournalSubscribeTask
 
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.MapFetchEntriesMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchKeysMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchNearCacheInvalidationMetadataTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchWithQueryMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetEntryViewMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapMadePublishableMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionWithPredicateMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateWithValueMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentWithMaxIdleMessageTask
 
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.MapPutTransientWithMaxIdleMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutWithMaxIdleMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveAllMessageTask
 
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.MapSetReadCursorMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetTtlMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetWithMaxIdleMessageTask
 
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.metrics.ReadMetricsMessageTask
 
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.MultiMapDeleteMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapGetMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapPutMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValueCountMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddAllMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueClearMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRemoveAllMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRetainAllMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsAllMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMaxSizeMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIsEmptyMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIteratorMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueOfferMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePeekMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePollMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePutMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemainingCapacityMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueSizeMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueTakeMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddAllMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferCapacityMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferHeadSequenceMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadManyMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadOneMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferRemainingCapacityMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferSizeMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferTailSequenceMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorGetAllScheduledMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorShutdownMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToAddressMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToPartitionMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromAddressMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromPartitionMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromAddressMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromPartitionMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromAddressMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromPartitionMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromAddressMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromPartitionMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromAddressMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromPartitionMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromAddressMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromPartitionMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromAddressMessageTask
 
getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromPartitionMessageTask
 
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.cp.internal.datastructures.atomiclong.client.AddAndGetMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.AlterMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.ApplyMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.CompareAndSetMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetAndAddMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetAndSetMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.ApplyMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.CompareAndSetMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.ContainsMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.GetMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.SetMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.AwaitMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.CountDownMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.GetCountMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.GetRoundMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.TrySetCountMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.GetLockOwnershipStateMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.LockMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.TryLockMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.UnlockMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.AcquirePermitsMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.AvailablePermitsMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.ChangePermitsMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.DrainPermitsMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.GetSemaphoreTypeMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.InitSemaphoreMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.ReleasePermitsMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.spi.client.CreateRaftGroupMessageTask
 
getMethodName() - Method in class com.hazelcast.cp.internal.datastructures.spi.client.DestroyRaftObjectMessageTask
 
getMethodName() - Method in class com.hazelcast.flakeidgen.impl.client.NewIdBatchMessageTask
 
getMethodName() - Method in enum com.hazelcast.internal.adapter.DataStructureAdapter.DataStructureMethods
 
getMethodName() - Method in interface com.hazelcast.internal.adapter.DataStructureAdapterMethod
 
getMethodName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterAddAndGetMessageTask
 
getMethodName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterDecrementAndGetMessageTask
 
getMethodName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndAddMessageTask
 
getMethodName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndIncrementMessageTask
 
getMethodName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndSetMessageTask
 
getMethodName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetMessageTask
 
getMethodName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterIncrementAndGetMessageTask
 
getMethodName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterSetMessageTask
 
getMetricsConfig() - Method in class com.hazelcast.client.config.ClientConfig
Returns the metrics collection config.
getMetricsConfig() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getMetricsConfig() - Method in class com.hazelcast.config.Config
Returns the metrics collection config.
getMetricsConfig() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getMetricsRegistry() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getMetricsRegistry() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getMetricTagger(String) - Method in interface com.hazelcast.internal.metrics.MetricTaggerSupplier
Gets the MetricTagger with the given namespace.
getMigrationData(PartitionReplicationEvent) - Method in class com.hazelcast.collection.impl.collection.CollectionService
 
getMigrationEndpoint() - Method in class com.hazelcast.spi.partition.PartitionMigrationEvent
Gets the partition migration endpoint.
getMigrationEvent() - Method in class com.hazelcast.internal.partition.operation.MigrationOperation
 
getMigrationEvent() - Method in class com.hazelcast.internal.partition.operation.MigrationRequestOperation
 
getMigrationInterceptor() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getMigrationManager() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getMigrationOperations() - Method in class com.hazelcast.internal.partition.ReplicaFragmentMigrationState
 
getMigrationParticipantType() - Method in class com.hazelcast.internal.partition.operation.MigrationOperation
 
getMigrationParticipantType() - Method in class com.hazelcast.internal.partition.operation.MigrationRequestOperation
 
getMigrationQueueSize() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getMigrationQueueSize() - Method in class com.hazelcast.monitor.impl.MemberPartitionStateImpl
 
getMigrationQueueSize() - Method in interface com.hazelcast.monitor.MemberPartitionState
Returns the migration queue size (this statistic is valid only for master).
getMigrationQueueSize() - Method in interface com.hazelcast.spi.partition.IPartitionService
 
getMigrationStamp() - Method in class com.hazelcast.map.impl.MapService
 
getMigrationStamp() - Method in class com.hazelcast.spi.impl.CountingMigrationAwareService
Returns a stamp to denote current migration state which can later be validated using CountingMigrationAwareService.validateMigrationStamp(int).
getMigrationState() - Method in class com.hazelcast.internal.partition.ReplicaMigrationEventImpl
 
getMigrationState() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
Returns the progress information of the overall migration.
getMillis(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty converted to milliseconds.
getMimeTypes() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
 
getMinAge() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
getMinAge() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the minimum age of the items in this member.
getMinBlockSize() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns the minimum memory block size, in bytes, to be served by native memory manager.
getMinimumClusterSize() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
getMinimumClusterSize() - Method in class com.hazelcast.splitbrainprotection.impl.SplitBrainProtectionImpl
 
getMinimumLevel() - Method in class com.hazelcast.config.MetricsConfig
Returns the minimum probe level to be collected.
getMinor() - Method in class com.hazelcast.version.MemberVersion
 
getMinor() - Method in class com.hazelcast.version.Version
 
getMinorCollectionCount() - Method in class com.hazelcast.internal.memory.DefaultGarbageCollectorStats
 
getMinorCollectionCount() - Method in interface com.hazelcast.internal.memory.GarbageCollectorStats
Returns minor collection count.
getMinorCollectionCount() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
 
getMinorCollectionTime() - Method in class com.hazelcast.internal.memory.DefaultGarbageCollectorStats
 
getMinorCollectionTime() - Method in interface com.hazelcast.internal.memory.GarbageCollectorStats
Returns total minor collection time in ms.
getMinorCollectionTime() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
 
getMinStdDeviationMillis() - Method in class com.hazelcast.splitbrainprotection.impl.ProbabilisticSplitBrainProtectionFunction
 
getMissedSequenceCount() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataContainer
 
getMisses() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
getMisses() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the number of misses of Near Cache entries owned by this member.
getMissingCPMemberAutoRemovalSeconds() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the duration to wait before automatically removing a missing CP member from CP Subsystem
getMode() - Method in class com.hazelcast.cp.internal.raft.impl.command.UpdateRaftGroupMembersCmd
 
getModifier() - Method in class com.hazelcast.query.impl.getters.AbstractMultiValueGetter
 
getModifierSuffix(String, String) - Static method in class com.hazelcast.query.impl.getters.SuffixModifierUtils
Get modifier suffix if fullName contains any otherwise returns null.
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.clientside.HazelcastClientInstanceImpl
 
getMultiMap(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getMultiMap(String) - Method in class com.hazelcast.client.impl.proxy.txn.TransactionContextProxy
 
getMultiMap(String) - Method in class com.hazelcast.client.impl.proxy.txn.xa.XATransactionContextProxy
 
getMultiMap() - Method in class com.hazelcast.console.ConsoleApp
 
getMultiMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed multimap instance with the specified name.
getMultiMap(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getMultiMap(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getMultiMap(String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
 
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.client.impl.clientside.ClientDynamicClusterConfig
 
getMultiMapConfig(String) - Method in class com.hazelcast.config.Config
Returns the MultiMapConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getMultiMapConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getMultiMapConfigs() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getMultiMapConfigs() - Method in class com.hazelcast.config.Config
Returns the map of MultiMap configurations, mapped by config name.
getMultiMapConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
getMultiMapConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Returns all registered multimap configurations.
getMultiMapConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getMultiMapContainer(String) - Method in class com.hazelcast.multimap.impl.MultiMapPartitionContainer
 
getMultiplier() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
factor with which to multiply backoff after a failed retry
getMutualAuthConfig() - Method in class com.hazelcast.config.ManagementCenterConfig
Gets a property.
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
Gets the name of the distributed object name of the cache.
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.event.AbstractICacheEvent
Returns the name of the cache for this event.
getName() - Method in interface com.hazelcast.cache.impl.event.ICacheEvent
Returns the name of the cache for this event.
getName() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Gets the name of the distributed object name of the cache.
getName() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorProxy
 
getName() - Method in class com.hazelcast.cardinality.impl.operations.AbstractCardinalityEstimatorOperation
 
getName() - Method in interface com.hazelcast.client.Client
This method may return null depending on the client version and the client type Java client provides client name starting with 3.12
getName() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
Returns the configuration name.
getName() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Gets the name of the reliable topic.
getName() - Method in class com.hazelcast.client.impl.client.DistributedObjectInfo
 
getName() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
getName() - Method in class com.hazelcast.client.impl.ClientEvent
 
getName() - Method in class com.hazelcast.client.impl.ClientImpl
 
getName() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getName() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getName() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
getName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.NearCacheConfigHolder
 
getName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
getName() - Method in class com.hazelcast.client.impl.spi.ClientContext
 
getName() - Method in class com.hazelcast.client.impl.spi.ClientProxy
 
getName() - Method in interface com.hazelcast.collection.ICollection
Returns the name of this collection.
getName() - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
getName() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
getName() - Method in class com.hazelcast.collection.impl.collection.CollectionEvent
 
getName() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
 
getName() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
 
getName() - Method in class com.hazelcast.collection.impl.queue.QueueEvent
 
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.config.AbstractBasicConfig
Gets the name of this data structure.
getName() - Method in class com.hazelcast.config.AttributeConfig
Gets the name of the attribute extracted by the extractor.
getName() - Method in class com.hazelcast.config.CacheConfig
Gets the name of this ICache.
getName() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the name of this ICache.
getName() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Gets the name of the cardinality estimator.
getName() - Method in class com.hazelcast.config.CollectionConfig
Gets the name of this collection.
getName() - Method in class com.hazelcast.config.cp.FencedLockConfig
Returns the name of FencedLock
getName() - Method in class com.hazelcast.config.cp.SemaphoreConfig
Returns the name of CP ISemaphore
getName() - Method in class com.hazelcast.config.DurableExecutorConfig
Gets the name of the executor task.
getName() - Method in class com.hazelcast.config.EndpointConfig
 
getName() - Method in class com.hazelcast.config.ExecutorConfig
Gets the name of the executor task.
getName() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Returns the configuration name.
getName() - Method in class com.hazelcast.config.IndexConfig
Gets name of the index.
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 interface com.hazelcast.config.NamedConfig
 
getName() - Method in class com.hazelcast.config.NearCacheConfig
Returns the name of the Near Cache.
getName() - Method in class com.hazelcast.config.PermissionConfig
 
getName() - Method in class com.hazelcast.config.PNCounterConfig
Gets the name of the PN counter.
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.ReliableTopicConfig
Gets the name of the reliable topic.
getName() - Method in class com.hazelcast.config.ReplicatedMapConfig
Returns the name of this ReplicatedMap.
getName() - Method in class com.hazelcast.config.RingbufferConfig
Returns the name of the ringbuffer.
getName() - Method in class com.hazelcast.config.ScheduledExecutorConfig
Gets the name of the executor task.
getName() - Method in class com.hazelcast.config.ServiceConfig
 
getName() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
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
Returns the WAN replication reference name.
getName() - Method in interface com.hazelcast.core.DistributedObject
Returns the unique name for this DistributedObject.
getName(DistributedObject) - Static method in class com.hazelcast.core.DistributedObjectUtil
Gets the name of the given distributed object.
getName() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the name of this Hazelcast instance.
getName() - Method in interface com.hazelcast.cp.CPGroupId
Returns name of the CP group.
getName() - Method in interface com.hazelcast.cp.IAtomicLong
Returns the name of this IAtomicLong instance.
getName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
getName() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
getName() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.proxy.CountDownLatchProxy
 
getName() - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
getName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionAwareSemaphoreProxy
 
getName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionlessSemaphoreProxy
 
getName() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.BlockingResource
 
getName() - Method in class com.hazelcast.cp.internal.RaftGroupId
 
getName() - Method in interface com.hazelcast.cp.ISemaphore
Returns the name of this ISemaphore instance.
getName() - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorContainer
 
getName() - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
getName(UUID) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
 
getName() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
getName() - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
 
getName() - Method in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorProxy
 
getName() - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getName() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getName() - Method in interface com.hazelcast.internal.crdt.CRDTReplicationAwareService
Returns the name of the service
getName() - Method in class com.hazelcast.internal.crdt.pncounter.operations.AbstractPNCounterOperation
 
getName() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterProxy
 
getName() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterService
 
getName() - Method in class com.hazelcast.internal.jmx.AtomicLongMBean
 
getName() - Method in class com.hazelcast.internal.jmx.AtomicReferenceMBean
 
getName() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getName() - Method in class com.hazelcast.internal.jmx.ListMBean
 
getName() - Method in class com.hazelcast.internal.jmx.ManagedExecutorServiceMBean
 
getName() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getName() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getName() - Method in class com.hazelcast.internal.jmx.NodeMBean
 
getName() - Method in class com.hazelcast.internal.jmx.QueueMBean
 
getName() - Method in class com.hazelcast.internal.jmx.ReliableTopicMBean
 
getName() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
getName() - Method in class com.hazelcast.internal.jmx.SemaphoreMBean
 
getName() - Method in class com.hazelcast.internal.jmx.SetMBean
 
getName() - Method in class com.hazelcast.internal.jmx.TopicMBean
 
getName() - Method in class com.hazelcast.internal.json.JsonObject.Member
Returns the name of this member.
getName() - Method in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
getName() - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
getName() - Method in class com.hazelcast.internal.longregister.operations.AbstractLongRegisterOperation
 
getName() - Method in interface com.hazelcast.internal.metrics.Metric
Gets the name that identifies this metric.
getName() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
getName() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidation
 
getName() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingHandler
 
getName() - Method in interface com.hazelcast.internal.nearcache.NearCache
Gets the name of this NearCache instance.
getName() - Method in class com.hazelcast.internal.serialization.impl.FieldDefinitionImpl
 
getName() - Method in class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
getName() - Method in interface com.hazelcast.internal.util.executor.ManagedExecutorService
 
getName() - Method in class com.hazelcast.internal.util.executor.NamedThreadPoolExecutor
 
getName() - Method in class com.hazelcast.map.AbstractIMapEvent
Returns the name of the map for this event.
getName() - Method in class com.hazelcast.map.EventLostEvent
 
getName() - Method in interface com.hazelcast.map.IMapEvent
Returns the name of the map for this event.
getName() - Method in class com.hazelcast.map.impl.MapContainer
 
getName() - Method in class com.hazelcast.map.impl.querycache.event.BatchIMapEvent
 
getName() - Method in class com.hazelcast.map.impl.querycache.event.SingleIMapEvent
 
getName() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
getName() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
getName() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
 
getName() - Method in interface com.hazelcast.map.QueryCache
Returns the name of this QueryCache.
getName() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
getName() - Method in interface com.hazelcast.monitor.MemberState
Returns the name of a Hazelcast member.
getName() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
getName() - Method in class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
 
getName() - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
 
getName() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
getName() - Method in class com.hazelcast.query.impl.AbstractIndex
 
getName() - Method in interface com.hazelcast.query.impl.Index
 
getName() - Method in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
 
getName() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperation
 
getName() - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsKeyOperation
 
getName() - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsValueOperation
 
getName() - Method in class com.hazelcast.replicatedmap.impl.operation.EntrySetOperation
 
getName() - Method in class com.hazelcast.replicatedmap.impl.operation.EvictionOperation
 
getName() - Method in class com.hazelcast.replicatedmap.impl.operation.GetOperation
 
getName() - Method in class com.hazelcast.replicatedmap.impl.operation.IsEmptyOperation
 
getName() - Method in class com.hazelcast.replicatedmap.impl.operation.KeySetOperation
 
getName() - Method in class com.hazelcast.replicatedmap.impl.operation.MergeOperation
 
getName() - Method in class com.hazelcast.replicatedmap.impl.operation.PutAllOperation
 
getName() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateOperation
 
getName() - Method in class com.hazelcast.replicatedmap.impl.operation.SizeOperation
 
getName() - Method in class com.hazelcast.replicatedmap.impl.operation.ValuesOperation
 
getName() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
getName() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
getName() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
getName() - Method in class com.hazelcast.ringbuffer.impl.operations.AbstractRingBufferOperation
 
getName() - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
 
getName() - Method in class com.hazelcast.scheduledexecutor.impl.NamedTaskDecorator
 
getName() - Method in class com.hazelcast.scheduledexecutor.impl.operations.AbstractSchedulerOperation
 
getName() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
getName() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
getName() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledRunnableAdapter
 
getName() - Method in class com.hazelcast.scheduledexecutor.impl.TaskDefinition
 
getName() - Method in interface com.hazelcast.scheduledexecutor.NamedTask
Returns the name of the task.
getName() - Method in interface com.hazelcast.security.Credentials
 
getName() - Method in class com.hazelcast.security.SimpleTokenCredentials
Simple implementation which returns "<empty>" for null tokens and "<token>" for all other tokens.
getName() - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
getName() - Method in class com.hazelcast.spi.impl.operationservice.AbstractNamedOperation
 
getName() - Method in interface com.hazelcast.spi.impl.operationservice.NamedOperation
Returns the name of the distributed data structure.
getName() - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
 
getName() - Method in class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectEventPacket
 
getName() - Method in class com.hazelcast.spi.impl.servicemanager.ServiceInfo
 
getName() - Method in class com.hazelcast.spi.properties.HazelcastProperty
Returns the property name.
getName() - Method in class com.hazelcast.splitbrainprotection.impl.SplitBrainProtectionImpl
 
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 interface com.hazelcast.topic.ITopic
Returns the name of this ITopic instance.
getName() - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
 
getName() - Method in class com.hazelcast.wan.impl.DelegatingWanReplicationScheme
 
getNameAsPartitionAwareData() - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
getNamePartitionSequenceList() - Method in class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation.MetaDataResponse
 
getNamePartitionSequenceList() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationMetaDataFetcher.MetadataHolder
 
getNamePartitionSequenceList() - Method in class com.hazelcast.map.impl.operation.MapGetInvalidationMetaDataOperation.MetaDataResponse
 
getNames() - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
 
getNames() - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
Gets a set of all current probe names.
getNames() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
 
getNamespace() - Method in class com.hazelcast.internal.locksupport.LockProxySupport
 
getNamespace() - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
getNamespace() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
 
getNamespaces(int) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
 
getNamespaces(int) - Method in interface com.hazelcast.internal.partition.PartitionReplicaVersionManager
Returns all registered namespaces for given partition ID
getNamespaceType() - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
getNamespaceURI() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getNamespaceVersionMap() - Method in class com.hazelcast.internal.partition.ReplicaFragmentMigrationState
 
getNameStart() - Method in class com.hazelcast.json.internal.JsonSchemaNameValue
Points to name of the object described in JsonSchemaNameValue.getValue().
getNameWithPrefix() - Method in class com.hazelcast.config.CacheConfig
Gets the full name of the ICache, including the manager scope prefix.
getNanos(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty converted to nanoseconds.
getNativeCache() - Method in class com.hazelcast.spring.cache.HazelcastCache
 
getNativeMemoryConfig() - Method in class com.hazelcast.client.config.ClientConfig
 
getNativeMemoryConfig() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getNativeMemoryConfig() - Method in class com.hazelcast.config.Config
Returns the native memory configuration for this hazelcast instance.
getNativeMemoryConfig() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getNearCache() - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
getNearCache() - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
getNearCache(String) - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
 
getNearCache(String) - Method in interface com.hazelcast.internal.nearcache.NearCacheManager
Gets the NearCache instance associated with given name.
getNearCache() - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
getNearCacheConfig(String) - Method in class com.hazelcast.client.config.ClientConfig
Gets the NearCacheConfig configured for the map / cache with name
getNearCacheConfig() - Method in class com.hazelcast.config.MapConfig
Returns the Near Cache configuration
getNearCacheConfig() - Method in class com.hazelcast.internal.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
getNearCacheManager() - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
Gets the related NearCacheManager with the underlying client instance.
getNearCacheManager() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getNearCacheManager() - Method in class com.hazelcast.client.impl.spi.ClientContext
 
getNearCacheRecordStore() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
getNearCacheStatistics() - Method in interface com.hazelcast.cache.CacheStatistics
Gets the Near Cache statistics.
getNearCacheStatistics() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
getNearCacheStatistics() - Method in class com.hazelcast.client.cache.impl.ClientCacheStatisticsImpl
 
getNearCacheStats() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
getNearCacheStats() - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
getNearCacheStats() - Method in interface com.hazelcast.internal.nearcache.NearCache
Get the NearCacheStats instance to monitor this store.
getNearCacheStats() - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
Get the NearCacheStats instance to monitor this record store.
getNearCacheStats() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
getNearCacheStats() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
getNearCacheStats() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
getNearCacheStats() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns statistics related to the Near Cache.
getNearestAnchorEntry() - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
 
getNearestAnchorEntry(PagingPredicate) - Static method in class com.hazelcast.query.PagingPredicateAccessor
 
getNetworkConfig() - Method in class com.hazelcast.client.config.ClientConfig
getNetworkConfig() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getNetworkConfig() - Method in class com.hazelcast.config.Config
Returns the network configuration for this hazelcast instance.
getNetworkConfig() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getNetworking() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
getNetworking() - Method in interface com.hazelcast.internal.nio.NetworkingService
Returns the Networking engine Shared across the multiple (or not) endpoints
getNetworking() - Method in class com.hazelcast.internal.nio.tcp.TcpIpNetworkingService
 
getNetworkingService() - Method in class com.hazelcast.instance.impl.Node
 
getNetworkingService() - Method in class com.hazelcast.internal.jmx.NetworkingServiceMBean
 
getNetworkingService() - Method in class com.hazelcast.internal.nio.tcp.TcpIpEndpointManager
 
getNetworkingServiceMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getNetworkStats() - Method in interface com.hazelcast.internal.nio.AggregateEndpointManager
Returns network stats for inbound and outbound traffic per EndpointQualifier.
getNetworkStats() - Method in class com.hazelcast.internal.nio.DefaultAggregateEndpointManager
 
getNetworkStats() - Method in interface com.hazelcast.internal.nio.EndpointManager
Returns network stats for inbound and outbound traffic.
getNetworkStats() - Method in class com.hazelcast.internal.nio.tcp.ClientViewUnifiedEndpointManager
 
getNetworkStats() - Method in class com.hazelcast.internal.nio.tcp.MemberViewUnifiedEndpointManager
 
getNetworkStats() - Method in class com.hazelcast.internal.nio.tcp.TcpIpEndpointManager
 
getNetworkStats() - Method in class com.hazelcast.internal.nio.tcp.TextViewUnifiedEndpointManager
 
getNetworkStats() - Method in class com.hazelcast.internal.nio.UnifiedAggregateEndpointManager
 
getNewestSequence() - Method in class com.hazelcast.internal.journal.EventJournalInitialSubscriberState
 
getNewReplicaIndex() - Method in class com.hazelcast.spi.partition.PartitionMigrationEvent
Gets the index of the partition replica that current member will own after migration is committed.
getNewState() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateChange
 
getNewValue() - Method in class com.hazelcast.cache.impl.journal.DeserializingEventJournalCacheEvent
 
getNewValue() - Method in interface com.hazelcast.cache.impl.journal.EventJournalCacheEvent
Returns the new value for the event entry.
getNewValue() - Method in class com.hazelcast.map.impl.journal.DeserializingEventJournalMapEvent
 
getNewValue() - Method in class com.hazelcast.map.impl.operation.EntryOperator
 
getNewValue() - Method in interface com.hazelcast.map.journal.EventJournalMapEvent
Returns the new value for the event entry.
getNewValueData() - Method in class com.hazelcast.map.impl.DataAwareEntryEvent
 
getNext() - Method in class com.hazelcast.query.impl.getters.JsonPathCursor
Returns the next attribute path part.
getNextRecordId() - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
 
getNextReferenceId() - Method in class com.hazelcast.client.impl.clientside.ClientLockReferenceIdGenerator
 
getNextSequenceToReadFrom() - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
 
getNextSequenceToReadFrom() - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
 
getNextSequenceToReadFrom() - Method in interface com.hazelcast.ringbuffer.ReadResultSet
Returns the sequence of the item following the last read item.
getNextSibling() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getNextTableIndexToReadFrom() - Method in class com.hazelcast.map.impl.iterator.AbstractCursor
 
getNextTableIndexToReadFrom() - Method in class com.hazelcast.map.impl.query.ResultSegment
 
getNextTableIndexToReadFrom() - Method in class com.hazelcast.query.impl.QueryableEntriesSegment
 
getNode() - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
getNode() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
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.collection.impl.queue.QueueService
 
getNodeEngine() - Method in class com.hazelcast.cp.internal.RaftOp
 
getNodeEngine() - Method in class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
 
getNodeEngine() - Method in class com.hazelcast.instance.impl.Node
 
getNodeEngine() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getNodeEngine() - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getNodeEngine() - Method in interface com.hazelcast.map.impl.MapServiceFactory
Returns a NodeEngine implementation.
getNodeEngine() - Method in class com.hazelcast.map.impl.querycache.publisher.DefaultPublisherContext
 
getNodeEngine() - Method in interface com.hazelcast.map.impl.querycache.publisher.PublisherContext
Returns underlying NodeEngine for this node.
getNodeEngine() - Method in class com.hazelcast.multimap.impl.MultiMapService
 
getNodeEngine() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
getNodeEngine() - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
getNodeEngine() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
getNodeEngine() - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
Gets the node engine.
getNodeEngine() - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
getNodeEntries() - Method in class com.hazelcast.map.impl.MerkleTreeNodeEntries
 
getNodeExtension() - Method in class com.hazelcast.instance.impl.Node
 
getNodeFilter() - Method in class com.hazelcast.config.DiscoveryConfig
 
getNodeFilterClass() - Method in class com.hazelcast.config.DiscoveryConfig
 
getNodeHash(int) - Method in class com.hazelcast.wan.impl.merkletree.ArrayMerkleTree
 
getNodeHash(int) - Method in class com.hazelcast.wan.impl.merkletree.RemoteMerkleTreeView
 
getNodeIdOffset() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getNodeKeyCount(int) - Method in class com.hazelcast.wan.impl.merkletree.ArrayMerkleTree
 
getNodeKeyCount(int) - Method in interface com.hazelcast.wan.impl.merkletree.MerkleTree
Returns the number of the keys under the specified node.
getNodeMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getNodeName() - Method in enum com.hazelcast.config.PermissionConfig.PermissionType
 
getNodeName() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getNodeOrder() - Method in class com.hazelcast.map.impl.MerkleTreeNodeEntries
 
getNodesOnLevel(int) - Static method in class com.hazelcast.wan.impl.merkletree.MerkleTreeUtil
Returns the number of nodes on the provided level
getNodeState() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
getNodeState() - Method in class com.hazelcast.monitor.impl.NodeStateImpl
 
getNodeState() - Method in interface com.hazelcast.monitor.MemberState
 
getNodeState() - Method in interface com.hazelcast.monitor.NodeState
 
getNodeType() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getNodeValue() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getNodeWideUsedCapacityCounter() - Method in interface com.hazelcast.map.impl.MapServiceContext
 
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.TxnCommitOperation
 
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.durableexecutor.impl.operations.PutResultOperation
 
getNotifiedKey(Data) - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
getNotifiedKey() - Method in class com.hazelcast.internal.locksupport.operations.UnlockOperation
 
getNotifiedKey() - Method in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
 
getNotifiedKey() - Method in class com.hazelcast.map.impl.operation.NotifyMapFlushOperation
 
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 class com.hazelcast.ringbuffer.impl.RingbufferContainer
 
getNotifiedKey() - Method in class com.hazelcast.scheduledexecutor.impl.operations.ResultReadyNotifyOperation
 
getNotifiedKey() - Method in interface com.hazelcast.spi.impl.operationservice.Notifier
 
getNotLockedRecords() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
getNow() - Static method in class com.hazelcast.map.impl.eviction.EvictorImpl
 
getNow() - Method in class com.hazelcast.map.impl.query.PartitionScanRunner
 
getNow(V) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
getNow(V) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
getNow(V) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
getNumberOfAffectedEntries() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
 
getNumberOfAffectedEntries() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
 
getNumberOfBackupAcks() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
getNumberOfBackups() - Method in class com.hazelcast.client.impl.ClientBackupAwareResponse
 
getNumberOfDependents() - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
getNumberOfDependents() - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
getNumberOfDependents() - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
getNumberOfEntries() - Method in class com.hazelcast.map.impl.event.MapEventData
 
getNumberOfEntriesAffected() - Method in class com.hazelcast.map.impl.querycache.event.LocalCacheWideEventData
 
getNumberOfEntriesAffected() - Method in class com.hazelcast.map.MapEvent
Returns the number of entries affected by this event.
getObject(Object, long) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Returns the object reference at the supplied offset from the supplied object's base address.
getObject(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getObject(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getObject(JsonObject, String) - Static method in class com.hazelcast.internal.util.JsonUtil
Returns a field in a Json object as an object.
getObject(JsonObject, String, JsonObject) - Static method in class com.hazelcast.internal.util.JsonUtil
Returns a field in a Json object as an object.
getObject() - Method in class com.hazelcast.multimap.impl.MultiMapRecord
 
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
Deprecated.
since 3.5. Please use DistributedObjectEvent.getObjectName() instead.
getObjectName() - Method in class com.hazelcast.core.DistributedObjectEvent
Returns the name of related DistributedObject.
getObjectName() - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
getObjectName() - Method in class com.hazelcast.internal.locksupport.LockWaitNotifyKey
 
getObjectName() - Method in class com.hazelcast.internal.services.DistributedObjectNamespace
 
getObjectName() - Method in interface com.hazelcast.internal.services.ObjectNamespace
Gets the object name within the service.
getObjectName() - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
 
getObjectName() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
 
getObjectName() - Method in class com.hazelcast.ringbuffer.impl.RingbufferWaitNotifyKey
 
getObjectName() - Method in class com.hazelcast.spi.impl.operationservice.AbstractWaitNotifyKey
 
getObjectName() - Method in interface com.hazelcast.spi.impl.operationservice.WaitNotifyKey
Returns the object name of the wait notify object for this key.
getObjectName() - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyInfo
 
getObjectName() - Method in interface com.hazelcast.wan.WanAntiEntropyEvent
Returns the distributed structure (object) name on which this event occurred.
getObjectName() - Method in interface com.hazelcast.wan.WanReplicationEvent
Returns the name of the distributed object (map or cache) on which this event occurred.
getObjectNameForProxy(String) - Static method in class com.hazelcast.cp.internal.RaftService
 
getObjectNamespace() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
getObjectNamespace(String) - Static method in class com.hazelcast.cache.impl.CacheService
 
getObjectNamespace() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Returns ObjectNamespace associated with this record store.
getObjectNamespace() - Method in class com.hazelcast.map.impl.MapContainer
 
getObjectNamespace(String) - Static method in class com.hazelcast.map.impl.MapService
 
getObjectNamespace() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
getObjectVolatile(Object, long) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Gets the referenced object from given owner object as volatile by its offset.
getObjectVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getObjectVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
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
 
getOffloadableExecutorMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getOffset() - Method in exception com.hazelcast.internal.json.ParseException
Deprecated.
getOldestSequence() - Method in class com.hazelcast.internal.journal.EventJournalInitialSubscriberState
 
getOldValue() - Method in class com.hazelcast.cache.impl.CacheEntryEventImpl
 
getOldValue() - Method in class com.hazelcast.cache.impl.journal.DeserializingEventJournalCacheEvent
 
getOldValue() - Method in interface com.hazelcast.cache.impl.journal.EventJournalCacheEvent
Returns the old value for the event entry.
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.map.impl.journal.DeserializingEventJournalMapEvent
 
getOldValue() - Method in class com.hazelcast.map.impl.operation.EntryOperator
 
getOldValue() - Method in class com.hazelcast.map.impl.querycache.event.LocalEntryEventData
 
getOldValue() - Method in interface com.hazelcast.map.journal.EventJournalMapEvent
Returns the old value for the event entry.
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
 
getOldValueData() - Method in class com.hazelcast.map.impl.querycache.event.LocalEntryEventData
 
getOngoingReplicaSyncRequests() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getOnJoinPermissionOperation() - Method in class com.hazelcast.config.SecurityConfig
 
getOnJoinPermissionOperation() - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
GetOp - Class in com.hazelcast.cp.internal.datastructures.atomicref.operation
GetOp() - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.operation.GetOp
 
GetOp(String) - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.operation.GetOp
 
getOp() - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Gets the operation to execute.
getOperation() - Method in class com.hazelcast.internal.crdt.CRDTReplicationContainer
Returns the CRDT replication operation.
GetOperation - Class in com.hazelcast.internal.crdt.pncounter.operations
Query operation to retrieve the current value of the PNCounter.
GetOperation(String, VectorClock) - Constructor for class com.hazelcast.internal.crdt.pncounter.operations.GetOperation
Constructs the operation.
GetOperation() - Constructor for class com.hazelcast.internal.crdt.pncounter.operations.GetOperation
 
GetOperation - Class in com.hazelcast.internal.longregister.operations
 
GetOperation() - Constructor for class com.hazelcast.internal.longregister.operations.GetOperation
 
GetOperation(String) - Constructor for class com.hazelcast.internal.longregister.operations.GetOperation
 
GetOperation - Class in com.hazelcast.map.impl.operation
 
GetOperation() - Constructor for class com.hazelcast.map.impl.operation.GetOperation
 
GetOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.GetOperation
 
GetOperation - Class in com.hazelcast.replicatedmap.impl.operation
 
GetOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.GetOperation
 
GetOperation(String, Data) - Constructor for class com.hazelcast.replicatedmap.impl.operation.GetOperation
 
getOperationExecutor() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
getOperationExecutorQueueSize() - Method in class com.hazelcast.internal.jmx.OperationServiceMBean
 
getOperationExecutorQueueSize() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
getOperationExecutorQueueSize() - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
 
getOperationFactory() - Method in class com.hazelcast.client.impl.operations.OperationFactoryWrapper
 
getOperationFactory() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation
 
getOperationName() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
getOperationParker() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getOperationProvider(String) - Method in class com.hazelcast.client.impl.protocol.task.cache.AbstractCacheMessageTask
 
getOperationProvider(String) - Method in class com.hazelcast.map.impl.operation.MapOperationProviders
 
getOperationResponseHandler() - Method in class com.hazelcast.spi.impl.operationservice.Operation
Gets the OperationResponseHandler tied to this Operation.
getOperationService() - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
Gets the OperationService.
getOperationService() - Method in interface com.hazelcast.spi.impl.NodeEngine
Gets the OperationService.
getOperationService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getOperationServiceBean() - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
 
getOperationServiceMBean() - Method in class com.hazelcast.internal.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.internal.jmx.OperationServiceMBean
 
getOperationType() - Method in class com.hazelcast.cluster.MemberAttributeEvent
Returns the type of member attribute change for this MemberAttributeEvent.
getOption(ChannelOption<T>) - Method in interface com.hazelcast.internal.networking.ChannelOptions
Gets an option value.
getOrCalculate(K) - Method in class com.hazelcast.internal.util.Memoizer
Returns the value for the key, calculating it in the process if necessary.
getOrConnect(Address) - Method in interface com.hazelcast.client.impl.connection.ClientConnectionManager
 
getOrConnect(Address) - Method in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
getOrConnect(Address) - Method in interface com.hazelcast.internal.nio.EndpointManager
Gets the existing connection for a given address or connects.
getOrConnect(Address, boolean) - Method in interface com.hazelcast.internal.nio.EndpointManager
Gets the existing connection for a given address.
getOrConnect(Address) - Method in class com.hazelcast.internal.nio.tcp.ClientViewUnifiedEndpointManager
 
getOrConnect(Address, boolean) - Method in class com.hazelcast.internal.nio.tcp.ClientViewUnifiedEndpointManager
 
getOrConnect(Address) - Method in class com.hazelcast.internal.nio.tcp.MemberViewUnifiedEndpointManager
 
getOrConnect(Address, boolean) - Method in class com.hazelcast.internal.nio.tcp.MemberViewUnifiedEndpointManager
 
getOrConnect(Address) - Method in class com.hazelcast.internal.nio.tcp.TcpIpEndpointManager
 
getOrConnect(Address, boolean) - Method in class com.hazelcast.internal.nio.tcp.TcpIpEndpointManager
 
getOrConnect(Address) - Method in class com.hazelcast.internal.nio.tcp.TextViewUnifiedEndpointManager
 
getOrConnect(Address, boolean) - Method in class com.hazelcast.internal.nio.tcp.TextViewUnifiedEndpointManager
 
getOrCreate(T, ClassLoader, String) - Static method in class com.hazelcast.internal.nio.ClassLoaderUtil
Returns the instance, if not null, or constructs a new instance of the class using ClassLoaderUtil.newInstance(ClassLoader, String).
getOrCreate(String) - Method in class com.hazelcast.map.impl.querycache.publisher.MapListenerRegistry
 
getOrCreate(String) - Method in class com.hazelcast.map.impl.querycache.publisher.MapPublisherRegistry
 
getOrCreate(Integer) - Method in class com.hazelcast.map.impl.querycache.publisher.PartitionAccumulatorRegistry
 
getOrCreate(String) - Method in class com.hazelcast.map.impl.querycache.publisher.PublisherRegistry
 
getOrCreate(String) - Method in class com.hazelcast.map.impl.querycache.publisher.QueryCacheListenerRegistry
 
getOrCreate(K) - Method in interface com.hazelcast.map.impl.querycache.Registry
Returns item if it exists in this registry or creates it.
getOrCreate(String) - Method in class com.hazelcast.map.impl.querycache.subscriber.MapSubscriberRegistry
 
getOrCreate(String) - Method in class com.hazelcast.map.impl.querycache.subscriber.SubscriberRegistry
 
getOrCreateCache(String, CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
getOrCreateCacheContext(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
getOrCreateCacheContext(String) - Method in interface com.hazelcast.cache.impl.ICacheService
 
getOrCreateCallIdsForMember(Address) - Method in class com.hazelcast.spi.impl.operationservice.CallsPerMember
 
getOrCreateCollectionContainer(int, String) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
getOrCreateCollectionContainerWithoutAccess(int, String) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
getOrCreateConfiguration(String, String, String) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheConfigurator
 
getOrCreateConfiguration(String, String, String) - Method in interface com.hazelcast.map.impl.querycache.QueryCacheConfigurator
Returns QueryCacheConfig for the requested cacheName
getOrCreateConfiguration(String, String, String) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheConfigurator
 
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(String, boolean) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
getOrCreateContainer(String, boolean) - Method in class com.hazelcast.collection.impl.set.SetService
 
getOrCreateContainer(String) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorPartitionContainer
 
getOrCreateContainer() - Method in class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
 
getOrCreateContainer(int, ObjectNamespace, RingbufferConfig) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
Return the ringbuffer containter for the specified namespace.
getOrCreateContainer(String) - Method in class com.hazelcast.scheduledexecutor.impl.AbstractScheduledExecutorContainerHolder
 
getOrCreateContainer(String) - Method in interface com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainerHolder
 
getOrCreateContainerWithoutAccess() - Method in class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
 
getOrCreateEventData(String, Address, Data, Object, Object, Object, int, boolean) - Method in interface com.hazelcast.map.impl.event.EntryEventDataCache
If an EntryEventData for the given parameters is already cached then return the cached value, otherwise create, cache and return the EntryEventData.
getOrCreateHazelcastInstance() - Static method in class com.hazelcast.core.Hazelcast
Gets or creates a HazelcastInstance with the default XML configuration looked up in: System property: Hazelcast will first check if "hazelcast.config" system property is set to a file or a classpath:... path.
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.impl.HazelcastInstanceFactory
 
getOrCreateInstance(URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
 
getOrCreateInstance(URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.impl.HazelcastServerCachingProvider
 
getOrCreateInstance(URI, ClassLoader, Properties) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCachingProvider
 
getOrCreateListContainer() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
 
getOrCreateMultiMapContainer(String) - Method in class com.hazelcast.multimap.impl.MultiMapPartitionContainer
 
getOrCreateMultiMapContainer(String, boolean) - Method in class com.hazelcast.multimap.impl.MultiMapPartitionContainer
 
getOrCreateNearCache(String, NearCacheConfig) - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
 
getOrCreateNearCache(String, NearCacheConfig, DataStructureAdapter) - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
 
getOrCreateNearCache(String, NearCacheConfig) - Method in interface com.hazelcast.internal.nearcache.NearCacheManager
Creates a new NearCache with given configurations or returns existing one.
getOrCreateNearCache(String, NearCacheConfig, DataStructureAdapter) - Method in interface com.hazelcast.internal.nearcache.NearCacheManager
Creates a new NearCache with given configurations or returns existing one.
getOrCreateProxy(String, String) - Method in class com.hazelcast.client.impl.spi.ProxyManager
 
getOrCreateProxy(String, boolean) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyRegistry
Retrieves a DistributedObject proxy or creates it if it is not available.
getOrCreateProxyFuture(String, boolean, boolean) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyRegistry
Retrieves a DistributedObjectFuture or creates it if it is not available.
getOrCreateQueryCache(String, String, ConstructorFunction<String, InternalQueryCache<K, V>>) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheEndToEndProvider
 
getOrCreateQueryCacheConfig(String, String) - Method in class com.hazelcast.client.config.ClientConfig
 
getOrCreateRecordStore(String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
getOrCreateRecordStore(String) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
Gets or creates a cache record store with the prefixed cacheNameWithPrefix.
getOrCreateRecordStore(String, int) - Method in interface com.hazelcast.cache.impl.ICacheService
Gets or creates a cache record store with the prefixed cacheNameWithPrefix and partition ID.
getOrCreateRecordStore(String) - Method in class com.hazelcast.replicatedmap.impl.PartitionContainer
 
getOrCreateRegistry(String) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
 
getOrCreateToReserve(K, Data) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
getOrCreateToReserve(K, Data) - Method in class com.hazelcast.internal.nearcache.impl.store.BaseHeapNearCacheRecordStore
 
getOrCreateUniqueThreadId(RaftGroupId) - Method in class com.hazelcast.cp.internal.session.AbstractProxySessionManager
 
getOrCreateUniqueThreadId() - Method in class com.hazelcast.cp.internal.session.SessionAwareProxy
 
getOrCreateUuid(int) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataGenerator
 
getOrDefault(PropertyDefinition, T) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
Returns the value of the requested PropertyDefinition if available in the declarative or programmatic configuration (XML or Config API), otherwise it will return the given defaultValue.
getOrDefault(String, PropertyDefinition, T) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
Returns the value of the requested PropertyDefinition if available in the declarative or programmatic configuration (XML or Config API), can be found in the system's environment, or passed as a JVM property.
getOrderKey() - Method in class com.hazelcast.cache.impl.CacheEventContext
 
getOrderLock(String) - Method in class com.hazelcast.topic.impl.TopicService
 
getOrigin() - Method in class com.hazelcast.cache.impl.CacheEventContext
 
getOriginal() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getOriginClassName() - Method in exception com.hazelcast.client.UndefinedErrorCodeException
 
getOrInitRaftNode(CPGroupId) - Method in class com.hazelcast.cp.internal.RaftService
 
getOrInitRegistry(CPGroupId) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
getOrInitResource(String) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
getOrNull(String, String, String) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheConfigurator
 
getOrNull(String) - Method in class com.hazelcast.map.impl.querycache.publisher.MapListenerRegistry
 
getOrNull(String) - Method in class com.hazelcast.map.impl.querycache.publisher.MapPublisherRegistry
 
getOrNull(Integer) - Method in class com.hazelcast.map.impl.querycache.publisher.PartitionAccumulatorRegistry
 
getOrNull(String) - Method in class com.hazelcast.map.impl.querycache.publisher.PublisherRegistry
 
getOrNull(String) - Method in class com.hazelcast.map.impl.querycache.publisher.QueryCacheListenerRegistry
 
getOrNull(String, String, String) - Method in interface com.hazelcast.map.impl.querycache.QueryCacheConfigurator
Returns QueryCacheConfig for the requested cacheName or null
getOrNull(K) - Method in interface com.hazelcast.map.impl.querycache.Registry
Returns item if it exists in this registry otherwise returns null.
getOrNull(String) - Method in class com.hazelcast.map.impl.querycache.subscriber.MapSubscriberRegistry
 
getOrNull(String, String, String) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheConfigurator
 
getOrNull(String) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheFactory
 
getOrNull(String) - Method in class com.hazelcast.map.impl.querycache.subscriber.SubscriberRegistry
 
getOrNull(PropertyDefinition) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
Returns the value of the requested PropertyDefinition if available in the declarative or programmatic configuration (XML or Config API), otherwise it will return null.
getOrNull(String, PropertyDefinition) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
Returns the value of the requested PropertyDefinition if available in the declarative or programmatic configuration (XML or Config API), can be found in the system's environment, or passed as a JVM property.
getOrNullIfExpired(Record, long, boolean) - Method in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
getOrNullIfExpired(R, long, boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Check if record is reachable according to TTL or idle times.
getOrNullQueryCacheConfig(String, String) - Method in class com.hazelcast.client.config.ClientConfig
 
getOrPutIfAbsent(ConcurrentMap<K, V>, K, ConstructorFunction<K, V>) - Static method in class com.hazelcast.internal.util.ConcurrencyUtil
 
getOrPutSynchronized(ConcurrentMap<K, V>, K, Object, ConstructorFunction<K, V>) - Static method in class com.hazelcast.internal.util.ConcurrencyUtil
 
getOrPutSynchronized(ConcurrentMap<K, V>, K, ContextMutexFactory, ConstructorFunction<K, V>) - Static method in class com.hazelcast.internal.util.ConcurrencyUtil
 
getOrTriggerConnect(Address) - Method in interface com.hazelcast.client.impl.connection.ClientConnectionManager
 
getOrTriggerConnect(Address) - Method in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
getOtherOperationCount() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
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.client.config.ClientNetworkConfig
Returns the outbound port definitions.
getOutboundPortDefinitions() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getOutboundPortDefinitions() - Method in class com.hazelcast.config.EndpointConfig
 
getOutboundPortDefinitions() - Method in class com.hazelcast.config.NetworkConfig
 
getOutboundPorts() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the outbound ports.
getOutboundPorts() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getOutboundPorts() - Method in class com.hazelcast.config.EndpointConfig
 
getOutboundPorts() - Method in class com.hazelcast.config.NetworkConfig
 
getOutboundPorts(EndpointQualifier) - Method in interface com.hazelcast.internal.nio.IOService
 
getOutboundPorts(EndpointQualifier) - Method in class com.hazelcast.internal.nio.NodeIOService
 
getOutboundPorts(Collection<Integer>, Collection<String>) - Static method in class com.hazelcast.internal.util.AddressUtil
 
getOutboundQueueSize() - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
getOutboundQueueSize() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the outbound queue size on this member
getOutboundResponseHandler() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
getOutOfMemoryErrorCount() - Static method in class com.hazelcast.instance.impl.OutOfMemoryErrorDispatcher
Gets the number of OutOfMemoryErrors that have been reported.
getOutputStatement(String) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
 
getOutputThreads() - Method in class com.hazelcast.internal.networking.nio.NioNetworking
 
getOwnedEntryCost() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
getOwnedEntryCount() - Method in interface com.hazelcast.cache.CacheStatistics
Returns the owned entry count in the cache.
getOwnedEntryCount() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
getOwnedEntryCount() - Method in class com.hazelcast.client.cache.impl.ClientCacheStatisticsImpl
 
getOwnedEntryCount() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
getOwnedEntryCount() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
 
getOwnedEntryCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
getOwnedEntryCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
getOwnedEntryCount() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
getOwnedEntryCount() - Method in interface com.hazelcast.monitor.LocalCacheStats
Returns the owned entry count in the cache.
getOwnedEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of entries owned by this member.
getOwnedEntryCount() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the number of Near Cache entries owned by this member.
getOwnedEntryMemoryCost() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
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 Near Cache entries owned by this member.
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.internal.locksupport.LockResource
 
getOwner() - Method in interface com.hazelcast.partition.Partition
Returns the current member that owns this partition.
getOwnerBundle() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Gets the owner Bundle of this instance.
getOwnerDocument() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getOwnerInfo(Data) - Method in interface com.hazelcast.internal.locksupport.LockStore
Return a string representation of the owner of the lock for a specific key.
getOwnerInfo(Data) - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
getOwnerInfo(Data) - Method in class com.hazelcast.internal.locksupport.LockStoreProxy
 
getOwnerOrNull() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionImpl
 
getOwnerOrNull() - Method in interface com.hazelcast.spi.partition.IPartition
Returns the address of the owner of this partition.
getOwnerReplicaOrNull() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionImpl
 
getOwnerReplicaOrNull() - Method in interface com.hazelcast.internal.partition.InternalPartition
Returns the partition replica of the owner of this partition.
getOwnerService() - Method in interface com.hazelcast.osgi.HazelcastOSGiInstance
Gets the owner HazelcastOSGiService of this instance.
getOwnerUuid() - Method in class com.hazelcast.transaction.impl.SuspendedTransaction
 
getOwnerUuid() - Method in interface com.hazelcast.transaction.impl.Transaction
 
getOwnerUuid() - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
getOwnerUuid() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
 
getOwnerUuid() - Method in class com.hazelcast.transaction.impl.xa.XATransactionDTO
 
getPackages() - Method in class com.hazelcast.config.ClassFilter
Returns unmodifiable set of package names.
getPacketDispatcher() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getPacketType() - Method in class com.hazelcast.internal.nio.Packet
 
getPacketVersion() - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
 
getPage() - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
 
getPage() - Method in interface com.hazelcast.query.PagingPredicate
Returns the current page value.
getPageSize() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns the page size, in bytes, to be allocated by native memory manager as a single block.
getPageSize() - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
 
getPageSize() - Method in interface com.hazelcast.query.PagingPredicate
Returns the page size.
getParallelism() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Gets the configured number of Hot Restart store instance to create for one Hazelcast instance.
getParameter(String) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
 
getParameters() - Method in interface com.hazelcast.client.impl.client.SecureRequest
Used for SecurityInterceptor Parameters passed to the method by a distributedObject for map.put(key, value) parameters should be 'key' and 'value' parameters can be in binary or object form, underlying implementation will de-serialize lazily
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.AbstractRemoveListenerMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.AddBackupListenerMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionListenerMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
 
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.CacheAddNearCacheInvalidationListenerTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheContainsKeyMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheCreateConfigMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEntryProcessorMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalReadTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalSubscribeTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheFetchNearCacheInvalidationMetadataTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndRemoveMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetConfigMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateEntriesMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutIfAbsentMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheReplaceMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSetExpiryPolicyMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.Pre38CacheAddInvalidationListenerTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorAddMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorEstimateMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.ClientStatisticsMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterAddMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetConfiguredReplicaCountMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxiesMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.DeployClassesMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AbstractAddConfigMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorDisposeResultMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorIsShutdownMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveAndDisposeResultMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveResultMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorShutdownMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorSubmitToPartitionMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnAddressMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnPartitionMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.IsFailoverSupportedMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllWithIndexMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddListenerMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddWithIndexMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListClearMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRemoveAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRetainAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIndexOfMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIsEmptyMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIteratorMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListLastIndexOfMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListListIteratorMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveWithIndexMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSetMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSizeMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSubMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.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.MapAddListenerMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddNearCacheInvalidationListenerMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateWithPredicateMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsMessageTask
 
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.MapDestroyCacheMessageTask
 
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.MapEventJournalReadTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEventJournalSubscribeTask
 
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.MapFetchEntriesMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchKeysMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchNearCacheInvalidationMetadataTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchWithQueryMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetEntryViewMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapMadePublishableMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionWithPredicateMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateWithValueMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentWithMaxIdleMessageTask
 
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.MapPutTransientWithMaxIdleMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutWithMaxIdleMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveIfSameMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceIfSameMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetReadCursorMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetTtlMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetWithMaxIdleMessageTask
 
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.map.Pre38MapAddNearCacheEntryListenerMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.metrics.ReadMetricsMessageTask
 
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.MultiMapDeleteMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapGetMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapPutMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValueCountMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueClearMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRemoveAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRetainAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMaxSizeMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIsEmptyMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIteratorMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueOfferMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePeekMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePollMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePutMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemainingCapacityMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueSizeMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueTakeMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferCapacityMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferHeadSequenceMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadManyMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadOneMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferRemainingCapacityMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferSizeMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferTailSequenceMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorGetAllScheduledMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorShutdownMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToAddressMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToPartitionMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromAddressMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromPartitionMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromAddressMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromPartitionMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromAddressMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromPartitionMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromAddressMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromPartitionMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromAddressMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromPartitionMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromAddressMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromPartitionMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromAddressMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromPartitionMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddListenerMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetClearMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRemoveAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRetainAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetGetAllMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetIsEmptyMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetSizeMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicAddMessageListenerMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicPublishMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCommitMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCreateMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionRollbackMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAClearRemoteTransactionMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XACollectTransactionsMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAFinalizeTransactionMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCommitMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCreateMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionPrepareMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionRollbackMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListAddMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListRemoveMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListSizeMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapContainsKeyMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapDeleteMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetForUpdateMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapIsEmptyMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetWithPredicateMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutIfAbsentMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveIfSameMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceIfSameMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSetMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSizeMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesWithPredicateMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapGetMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapPutMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveEntryMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapSizeMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapValueCountMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueOfferMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePeekMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePollMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueSizeMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueTakeMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetAddMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetRemoveMessageTask
 
getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetSizeMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.AddAndGetMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.AlterMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.ApplyMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.CompareAndSetMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetAndAddMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetAndSetMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.ApplyMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.CompareAndSetMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.ContainsMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.GetMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.SetMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.AwaitMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.CountDownMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.GetCountMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.GetRoundMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.TrySetCountMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.GetLockOwnershipStateMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.LockMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.TryLockMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.UnlockMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.AcquirePermitsMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.AvailablePermitsMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.ChangePermitsMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.DrainPermitsMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.GetSemaphoreTypeMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.InitSemaphoreMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.ReleasePermitsMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.spi.client.CreateRaftGroupMessageTask
 
getParameters() - Method in class com.hazelcast.cp.internal.datastructures.spi.client.DestroyRaftObjectMessageTask
 
getParameters() - Method in class com.hazelcast.flakeidgen.impl.client.NewIdBatchMessageTask
 
getParameters() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterAddAndGetMessageTask
 
getParameters() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterDecrementAndGetMessageTask
 
getParameters() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndAddMessageTask
 
getParameters() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndIncrementMessageTask
 
getParameters() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndSetMessageTask
 
getParameters() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetMessageTask
 
getParameters() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterIncrementAndGetMessageTask
 
getParameters() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterSetMessageTask
 
getParameterTypes() - Method in enum com.hazelcast.internal.adapter.DataStructureAdapter.DataStructureMethods
 
getParameterTypes() - Method in interface com.hazelcast.internal.adapter.DataStructureAdapterMethod
 
getParameterTypeString() - Method in enum com.hazelcast.internal.adapter.DataStructureAdapter.DataStructureMethods
 
getParameterTypeString() - Method in interface com.hazelcast.internal.adapter.DataStructureAdapterMethod
 
getParent() - Method in class com.hazelcast.json.internal.JsonSchemaNode
Returns the parent.
getParent() - Method in class com.hazelcast.spi.properties.HazelcastProperty
Returns the parent GroupProperty of the property.
getParentNode() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getParentOrder(int) - Static method in class com.hazelcast.wan.impl.merkletree.MerkleTreeUtil
Returns the breadth-first order of the parent node of the node with nodeOrder
getParkQueueCount() - Method in class com.hazelcast.spi.impl.operationparker.impl.OperationParkerImpl
 
getParser(String) - Method in class com.hazelcast.internal.nio.ascii.TextParsers
 
getPartition(Object) - Method in class com.hazelcast.client.impl.proxy.PartitionServiceProxy
 
getPartition(int) - Method in interface com.hazelcast.client.impl.spi.ClientPartitionService
 
getPartition(int) - Method in class com.hazelcast.client.impl.spi.impl.ClientPartitionServiceImpl
 
getPartition(int) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getPartition(int, boolean) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getPartition(int) - Method in interface com.hazelcast.internal.partition.InternalPartitionService
 
getPartition(int, boolean) - Method in interface com.hazelcast.internal.partition.InternalPartitionService
 
getPartition(Object) - Method in class com.hazelcast.internal.partition.PartitionServiceProxy
 
getPartition(Object) - Method in interface com.hazelcast.partition.PartitionService
Returns the partition that the given key belongs to.
getPartition(int) - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
getPartition(int) - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns the IPartition for a given partition ID.
getPartition(int, boolean) - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns the IPartition for a given partition ID.
getPartitionContainer(int) - Method in class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
 
getPartitionContainer(int) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getPartitionContainer(int) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
getPartitionContainer(int) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
getPartitionContainers() - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getPartitionCount() - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
getPartitionCount() - Method in class com.hazelcast.client.impl.querycache.ClientQueryCacheContext
 
getPartitionCount() - Method in interface com.hazelcast.client.impl.spi.ClientPartitionService
 
getPartitionCount() - Method in class com.hazelcast.client.impl.spi.impl.ClientPartitionServiceImpl
 
getPartitionCount() - Method in class com.hazelcast.internal.jmx.PartitionServiceMBean
 
getPartitionCount() - Method in class com.hazelcast.internal.management.dto.PartitionServiceBeanDTO
 
getPartitionCount() - Method in interface com.hazelcast.internal.nearcache.impl.invalidation.MinimalPartitionService
Returns the number of partitions.
getPartitionCount() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getPartitionCount() - Method in class com.hazelcast.internal.util.collection.PartitionIdSet
 
getPartitionCount() - Method in class com.hazelcast.map.impl.nearcache.MemberMinimalPartitionService
 
getPartitionCount() - Method in class com.hazelcast.map.impl.querycache.NodeQueryCacheContext
 
getPartitionCount() - Method in interface com.hazelcast.map.impl.querycache.QueryCacheContext
 
getPartitionCount() - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns the number of partitions.
getPartitionEventManager() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getPartitionGroupConfig() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getPartitionGroupConfig() - Method in class com.hazelcast.config.Config
Returns the partition group configuration for this hazelcast instance.
getPartitionGroupConfig() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getPartitionGroupStrategy() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
 
getPartitionGroupStrategy() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
Returns a custom implementation of a PartitionGroupStrategy to override default behavior of zone aware backup strategies PartitionGroupMetaData or to provide a specific behavior in case the discovery environment does not provide information about the infrastructure to be used for automatic configuration.
getPartitionGroupStrategy() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
 
getPartitionHash() - Method in class com.hazelcast.internal.serialization.impl.HeapData
 
getPartitionHash() - Method in interface com.hazelcast.nio.serialization.Data
Returns partition hash calculated for serialized object.
getPartitionId() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
getPartitionId() - Method in class com.hazelcast.cache.impl.CachePartitionEventData
 
getPartitionId() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
 
getPartitionId(NodeEngine, Data) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
 
getPartitionId() - Method in class com.hazelcast.cache.impl.event.CachePartitionLostEvent
Returns the partition ID that has been lost for the given cache.
getPartitionId() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
 
getPartitionId() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorProxy
 
getPartitionId() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
getPartitionId() - Method in class com.hazelcast.client.impl.protocol.task.AbstractPartitionMessageTask
 
getPartitionId() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
 
getPartitionId() - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
 
getPartitionId() - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
 
getPartitionId(Object) - Method in class com.hazelcast.client.impl.querycache.ClientQueryCacheContext
 
getPartitionId(Data) - Method in interface com.hazelcast.client.impl.spi.ClientPartitionService
 
getPartitionId(Object) - Method in interface com.hazelcast.client.impl.spi.ClientPartitionService
 
getPartitionId() - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocation
 
getPartitionId(Data) - Method in class com.hazelcast.client.impl.spi.impl.ClientPartitionServiceImpl
 
getPartitionId(Object) - Method in class com.hazelcast.client.impl.spi.impl.ClientPartitionServiceImpl
 
getPartitionId() - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
getPartitionId() - Method in class com.hazelcast.cp.internal.util.PartitionSpecificRunnableAdaptor
 
getPartitionId() - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
getPartitionId(Data) - Method in interface com.hazelcast.internal.nearcache.impl.invalidation.MinimalPartitionService
Returns the partition ID for a Data key.
getPartitionId(Object) - Method in interface com.hazelcast.internal.nearcache.impl.invalidation.MinimalPartitionService
Returns the partition ID for a given object.
getPartitionId(Object) - Method in interface com.hazelcast.internal.nearcache.impl.invalidation.StaleReadDetector
 
getPartitionId(Object) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.StaleReadDetectorImpl
 
getPartitionId() - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
getPartitionId() - Method in interface com.hazelcast.internal.nearcache.NearCacheRecord
 
getPartitionId() - Method in class com.hazelcast.internal.nio.Packet
Returns the partition ID of this packet.
getPartitionId() - Method in class com.hazelcast.internal.partition.impl.AbstractPartitionPrimaryReplicaAntiEntropyTask
 
getPartitionId() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionImpl
 
getPartitionId(Data) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getPartitionId(Object) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getPartitionId() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
getPartitionId() - Method in class com.hazelcast.internal.partition.PartitionLostEventImpl
Returns the lost partition ID.
getPartitionId() - Method in class com.hazelcast.internal.partition.ReplicaMigrationEventImpl
 
getPartitionId() - Method in class com.hazelcast.map.EventLostEvent
 
getPartitionId() - Method in class com.hazelcast.map.impl.event.MapPartitionEventData
 
getPartitionId() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntry
 
getPartitionId(Data) - Method in class com.hazelcast.map.impl.nearcache.MemberMinimalPartitionService
 
getPartitionId(Object) - Method in class com.hazelcast.map.impl.nearcache.MemberMinimalPartitionService
 
getPartitionId() - Method in class com.hazelcast.map.impl.PartitionContainer
 
getPartitionId() - Method in class com.hazelcast.map.impl.querycache.event.BatchEventData
 
getPartitionId() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
getPartitionId() - Method in class com.hazelcast.map.impl.querycache.event.LocalEntryEventData
 
getPartitionId() - Method in interface com.hazelcast.map.impl.querycache.event.sequence.Sequenced
Returns partition ID which this sequence belongs to.
getPartitionId(Object) - Method in class com.hazelcast.map.impl.querycache.NodeQueryCacheContext
 
getPartitionId(Object) - Method in interface com.hazelcast.map.impl.querycache.QueryCacheContext
Returns partition ID of the supplied object.
getPartitionId() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Returns the partition id this RecordStore belongs to.
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.multimap.impl.MultiMapContainer
 
getPartitionId() - Method in interface com.hazelcast.partition.Partition
Returns the ID of the partition.
getPartitionId() - Method in interface com.hazelcast.partition.PartitionEvent
Returns the partition ID that the event is dispatched for.
getPartitionId() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
getPartitionId() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
getPartitionId() - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
 
getPartitionId() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
getPartitionId() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
 
getPartitionId() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Returns the partition ID the task is associated with.
getPartitionId(Data) - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
getPartitionId(Store) - Method in class com.hazelcast.spi.impl.merge.AbstractMergeRunnable
 
getPartitionId() - Method in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
Returns the partitionId this OperationRunner is responsible for.
getPartitionId() - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Returns the partition ID.
getPartitionId() - Method in class com.hazelcast.spi.impl.operationservice.Operation
Returns the ID of the partition that this Operation will be executed on.
getPartitionId() - Method in interface com.hazelcast.spi.impl.operationservice.PartitionAwareOperation
Gets the partition ID.
getPartitionId() - Method in interface com.hazelcast.spi.impl.PartitionSpecificRunnable
Returns the partition ID.
getPartitionId() - Method in class com.hazelcast.spi.impl.PortableCachePartitionLostEvent
 
getPartitionId() - Method in class com.hazelcast.spi.impl.PortableMapPartitionLostEvent
 
getPartitionId() - Method in class com.hazelcast.spi.impl.PortablePartitionLostEvent
 
getPartitionId() - Method in interface com.hazelcast.spi.partition.IPartition
Returns the partition ID.
getPartitionId() - Method in interface com.hazelcast.spi.partition.IPartitionLostEvent
The partition ID that is lost.
getPartitionId(Data) - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns the partition ID for a Data key.
getPartitionId(Object) - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns the partition ID for a given object.
getPartitionId() - Method in class com.hazelcast.spi.partition.PartitionMigrationEvent
Gets the partition ID.
getPartitionId() - Method in class com.hazelcast.spi.partition.PartitionReplicationEvent
Gets the ID of the partition.
getPartitionIds() - Method in class com.hazelcast.map.impl.query.AggregationResult
 
getPartitionIds() - Method in class com.hazelcast.map.impl.query.QueryResult
 
getPartitionIds() - Method in interface com.hazelcast.map.impl.query.Result
Returns partition IDs associated with this result or null if this result is an empty/failure result.
getPartitionImpl(int) - Method in class com.hazelcast.internal.partition.impl.PartitionStateManager
 
getPartitioningStrategy(ClassLoader) - Method in class com.hazelcast.client.impl.clientside.DefaultClientExtension
 
getPartitioningStrategy() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
getPartitioningStrategy(ClassLoader) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
getPartitioningStrategy() - Method in class com.hazelcast.map.impl.MapContainer
 
getPartitioningStrategy(String, PartitioningStrategyConfig) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getPartitioningStrategy(String, PartitioningStrategyConfig) - Method in class com.hazelcast.map.impl.PartitioningStrategyFactory
Obtain a PartitioningStrategy for the given NodeEngine and mapName.
getPartitioningStrategyClass() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
getPartitioningStrategyConfig() - Method in class com.hazelcast.config.MapConfig
 
getPartitioningStrategyConfig() - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
getPartitionKey() - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
getPartitionKey() - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
getPartitionKey() - Method in class com.hazelcast.client.cp.internal.datastructures.countdownlatch.CountDownLatchProxy
 
getPartitionKey() - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionAwareSemaphoreProxy
 
getPartitionKey() - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionlessSemaphoreProxy
 
getPartitionKey() - Method in class com.hazelcast.client.impl.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 class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
getPartitionKey() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
getPartitionKey() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.proxy.CountDownLatchProxy
 
getPartitionKey() - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
getPartitionKey() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionAwareSemaphoreProxy
 
getPartitionKey() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionlessSemaphoreProxy
 
getPartitionKey() - Method in class com.hazelcast.executor.impl.RunnableAdapter
 
getPartitionKey() - Method in class com.hazelcast.internal.jmx.AtomicLongMBean
 
getPartitionKey() - Method in class com.hazelcast.internal.jmx.AtomicReferenceMBean
 
getPartitionKey() - Method in class com.hazelcast.internal.jmx.CountDownLatchMBean
 
getPartitionKey() - Method in class com.hazelcast.internal.jmx.QueueMBean
 
getPartitionKey() - Method in class com.hazelcast.internal.jmx.SemaphoreMBean
 
getPartitionKey() - Method in class com.hazelcast.internal.jmx.SetMBean
 
getPartitionKey() - Method in interface com.hazelcast.partition.PartitionAware
The key that will be used by Hazelcast to specify the partition.
getPartitionKey() - Method in class com.hazelcast.partition.PartitionAwareKey
 
getPartitionKey(K) - Method in interface com.hazelcast.partition.PartitioningStrategy
Returns the key object that will be used by Hazelcast to specify the partition.
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.query.impl.predicates.PartitionPredicateImpl
Returns the partition key that determines the partition the target Predicate is going to execute on.
getPartitionKey() - Method in interface com.hazelcast.query.PartitionPredicate
Returns the partition key that determines the partition the target Predicate is going to execute on.
getPartitionKey() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
getPartitionKey() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledRunnableAdapter
 
getPartitionKey() - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
getPartitionListenerService() - Method in interface com.hazelcast.client.impl.ClientEngine
 
getPartitionListenerService() - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
getPartitionListenerService() - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.CacheConfig
Gets the partition lost listener references added to cache configuration.
getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the partition lost listener references added to cache configuration.
getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.MapConfig
 
getPartitionLostListenerConfigs() - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
getPartitionMigrationTimeout() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getPartitionOperationRunners() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
getPartitionOperationRunners() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
Gets all the operation handlers for the partitions.
getPartitionOrMemberBin(int) - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
getPartitionOwner(int) - Method in interface com.hazelcast.client.impl.spi.ClientPartitionService
 
getPartitionOwner(int) - Method in class com.hazelcast.client.impl.spi.impl.ClientPartitionServiceImpl
 
getPartitionOwner(int) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getPartitionOwner(int) - Method in interface com.hazelcast.spi.partition.IPartitionService
Gets the owner of the partition if it's set.
getPartitionOwnerOrWait(int) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getPartitionOwnerOrWait(int) - Method in interface com.hazelcast.spi.partition.IPartitionService
Gets the owner of the partition.
getPartitionReplicaStateChecker() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getPartitionReplicaStateChecker() - Method in interface com.hazelcast.internal.partition.InternalPartitionService
 
getPartitionReplicaVersionManager() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getPartitionReplicaVersionManager() - Method in interface com.hazelcast.internal.partition.InternalPartitionService
 
getPartitionReplicaVersions(int, ServiceNamespace) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
 
getPartitionReplicaVersions(int, ServiceNamespace) - Method in interface com.hazelcast.internal.partition.PartitionReplicaVersionManager
Returns replica versions for given partition and namespace.
getPartitions(PartitionTableView) - Method in class com.hazelcast.client.impl.ClientPartitionListenerService
If any partition does not have an owner, this method returns empty collection
getPartitions() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMultiPartitionMessageTask
 
getPartitions() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeysMessageTask
 
getPartitions() - Method in class com.hazelcast.client.impl.proxy.PartitionServiceProxy
 
getPartitions() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getPartitions() - Method in class com.hazelcast.internal.partition.PartitionServiceProxy
 
getPartitions() - Method in class com.hazelcast.monitor.impl.MemberPartitionStateImpl
 
getPartitions() - Method in interface com.hazelcast.monitor.MemberPartitionState
Returns a list of owned partitions of the member.
getPartitions() - Method in interface com.hazelcast.partition.PartitionService
Returns a set containing all the Partitions in the cluster.
getPartitions() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation.PartitionResponse
 
getPartitions() - Method in interface com.hazelcast.spi.partition.IPartitionService
Returns an array of IPartition instances.
getPartitionsCopy() - Method in class com.hazelcast.internal.partition.impl.PartitionStateManager
Returns a copy of the current partition table.
getPartitionSegments() - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
getPartitionSegments() - Method in interface com.hazelcast.cache.impl.ICacheService
 
getPartitionService() - Method in interface com.hazelcast.client.impl.ClientEngine
 
getPartitionService() - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
getPartitionService() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getPartitionService() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getPartitionService() - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
getPartitionService() - Method in class com.hazelcast.client.impl.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.impl.HazelcastInstanceImpl
 
getPartitionService() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getPartitionService() - Method in class com.hazelcast.instance.impl.Node
 
getPartitionService() - Method in interface com.hazelcast.spi.impl.NodeEngine
Gets the IPartitionService.
getPartitionService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getPartitionServiceBean() - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
 
getPartitionServiceMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getPartitionServiceProxy() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getPartitionServiceProxy() - Method in interface com.hazelcast.internal.partition.InternalPartitionService
Returns the PartitionServiceProxy of the partition service..
getPartitionServiceState() - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaStateChecker
 
getPartitionSet() - Method in interface com.hazelcast.wan.WanAntiEntropyEvent
Returns the set of partition IDs on which this event occurred.
GetPartitionsMessageTask - Class in com.hazelcast.client.impl.protocol.task
 
GetPartitionsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
 
getPartitionsSynced() - Method in class com.hazelcast.internal.management.events.WanSyncProgressUpdateEvent
 
getPartitionsSynced() - Method in interface com.hazelcast.wan.WanSyncStats
Returns the number of the partitions synchronized.
getPartitionStateManager() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getPartitionStateVersion() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getPartitionStateVersion() - Method in interface com.hazelcast.spi.partition.IPartitionService
 
getPartitionStoreAdapter() - Method in class com.hazelcast.query.impl.AbstractIndex
 
getPartitionsToSync() - Method in class com.hazelcast.internal.management.events.WanSyncProgressUpdateEvent
 
getPartitionsToSync() - Method in interface com.hazelcast.wan.WanSyncStats
Returns the number of the partitions to synchronize.
getPartitionTable() - Method in class com.hazelcast.internal.partition.PartitionRuntimeState
 
getPartitionThreadCount() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
getPartitionThreadCount() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
Returns the number of partition threads.
getPartitionThreadCount() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
getPartitionThreadCount() - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Returns the number of partition threads.
getPartitionThreadId(int) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
getPartitionThreadId(int) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
Returns the ID of the partitionThread assigned to handle partition with given partitionId
getPartitionUuid() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidation
 
getPartitionUuidList() - Method in class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation.MetaDataResponse
 
getPartitionUuidList() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationMetaDataFetcher.MetadataHolder
 
getPartitionUuidList() - Method in class com.hazelcast.map.impl.operation.MapGetInvalidationMetaDataOperation.MetaDataResponse
 
getPartitionVersionIncrement() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
getPassword() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Returns the Java KeyStore password.
getPassword() - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
Provides password for a chosen SecretKeyFactory.
getPassword() - Method in class com.hazelcast.config.replacer.EncryptionReplacer
 
getPassword() - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
 
getPassword() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
getPassword() - Method in interface com.hazelcast.security.PasswordCredentials
 
getPassword() - Method in class com.hazelcast.security.UsernamePasswordCredentials
Gets the password.
getPasswordAttribute() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getPatch() - Method in class com.hazelcast.version.MemberVersion
 
getPath() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Returns the Java KeyStore file path.
getPath(String...) - Static method in class com.hazelcast.internal.nio.IOUtil
Concatenates path parts to a single path using the File.separator where it applies.
getPath(String) - Static method in class com.hazelcast.query.impl.getters.AbstractJsonGetter
 
getPatternListSnapshot() - Method in class com.hazelcast.query.impl.getters.JsonGetterContext
 
getPayload() - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicMessage
 
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.
getPerIndexStats() - Method in class com.hazelcast.query.impl.AbstractIndex
 
getPerIndexStats() - Method in interface com.hazelcast.query.impl.InternalIndex
Returns the index stats associated with this index.
getPeriod() - Method in class com.hazelcast.scheduledexecutor.impl.TaskDefinition
 
getPeriodMillis() - Method in class com.hazelcast.internal.diagnostics.BuildInfoPlugin
 
getPeriodMillis() - Method in class com.hazelcast.internal.diagnostics.ConfigPropertiesPlugin
 
getPeriodMillis() - Method in class com.hazelcast.internal.diagnostics.DiagnosticsPlugin
Returns the period of executing the monitor in millis.
getPeriodMillis() - Method in class com.hazelcast.internal.diagnostics.EventQueuePlugin
 
getPeriodMillis() - Method in class com.hazelcast.internal.diagnostics.InvocationPlugin
 
getPeriodMillis() - Method in class com.hazelcast.internal.diagnostics.MemberHazelcastInstanceInfoPlugin
 
getPeriodMillis() - Method in class com.hazelcast.internal.diagnostics.MemberHeartbeatPlugin
 
getPeriodMillis() - Method in class com.hazelcast.internal.diagnostics.MetricsPlugin
 
getPeriodMillis() - Method in class com.hazelcast.internal.diagnostics.NetworkingImbalancePlugin
 
getPeriodMillis() - Method in class com.hazelcast.internal.diagnostics.OperationHeartbeatPlugin
 
getPeriodMillis() - Method in class com.hazelcast.internal.diagnostics.OperationThreadSamplerPlugin
 
getPeriodMillis() - Method in class com.hazelcast.internal.diagnostics.OverloadedConnectionsPlugin
 
getPeriodMillis() - Method in class com.hazelcast.internal.diagnostics.PendingInvocationsPlugin
 
getPeriodMillis() - Method in class com.hazelcast.internal.diagnostics.SlowOperationPlugin
 
getPeriodMillis() - Method in class com.hazelcast.internal.diagnostics.StoreLatencyPlugin
 
getPeriodMillis() - Method in class com.hazelcast.internal.diagnostics.SystemLogPlugin
 
getPeriodMillis() - Method in class com.hazelcast.internal.diagnostics.SystemPropertiesPlugin
 
getPermission(String, String, String...) - Static method in class com.hazelcast.security.permission.ActionConstants
Creates a permission
getPermissionConfig() - Method in class com.hazelcast.internal.management.dto.PermissionConfigDTO
 
getPermissionConfigs() - Method in class com.hazelcast.internal.management.request.UpdatePermissionConfigRequest
 
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
 
getPersistenceCount() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
getPersistenceCount() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the number of Near Cache key persistences (when the pre-load feature is enabled).
getPersistentMemoryDirectory() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns the persistent memory directory (e.g.
getPlannedMigrations() - Method in class com.hazelcast.internal.partition.impl.MigrationStats
Returns the number of planned migrations on the latest repartitioning round.
getPlannedMigrations() - Method in class com.hazelcast.internal.partition.MigrationStateImpl
 
getPlannedMigrations() - Method in interface com.hazelcast.partition.MigrationState
Returns the number of planned migrations in the migration plan.
getPlugin(Class<P>) - Method in class com.hazelcast.internal.diagnostics.Diagnostics
Gets the plugin for a given plugin class.
getPNCounter(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getPNCounter(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getPNCounter(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns a PNCounter with the given name.
getPNCounter(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getPNCounter(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getPNCounterConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getPNCounterConfig(String) - Method in class com.hazelcast.config.Config
Returns the PNCounterConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getPNCounterConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getPNCounterConfigs() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getPNCounterConfigs() - Method in class com.hazelcast.config.Config
Returns the map of PN counter configurations, mapped by config name.
getPNCounterConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
getPNCounterConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Returns all registered PN counter configurations.
getPNCounterConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getPolicy() - Method in class com.hazelcast.config.MergePolicyConfig
Returns the classname of the SplitBrainMergePolicy.
getPollingInterval() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Returns the polling interval (in seconds) for checking for changes in the KeyStore.
getPollingInterval() - Method in class com.hazelcast.config.VaultSecureStoreConfig
Returns the Vault polling interval (in seconds).
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.DurableExecutorConfig
Gets the number of executor threads per member for the executor.
getPoolSize() - Method in class com.hazelcast.config.ExecutorConfig
Gets the number of executor threads per member for the executor.
getPoolSize() - Method in class com.hazelcast.config.ScheduledExecutorConfig
Gets the number of executor threads per member for the executor.
getPoolSize() - Method in class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
getPoolSize() - Method in interface com.hazelcast.internal.util.executor.ManagedExecutorService
 
getPort() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
getPort() - Method in class com.hazelcast.cluster.Address
 
getPort() - Method in class com.hazelcast.cluster.impl.AbstractMember
 
getPort() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
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.config.ServerSocketEndpointConfig
Returns the port the Hazelcast member will try to bind on.
getPort() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getPort() - Method in interface com.hazelcast.internal.nio.Connection
The remote port.
getPort() - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
getPort() - Method in class com.hazelcast.internal.util.AddressUtil.AddressHolder
 
getPort() - Method in class com.hazelcast.spi.discovery.multicast.impl.MulticastMemberInfo
 
getPortableContext() - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1
 
getPortableContext() - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
 
getPortableFactories() - Method in class com.hazelcast.config.SerializationConfig
 
getPortableFactoryClasses() - Method in class com.hazelcast.config.SerializationConfig
 
getPortableVersion() - Method in class com.hazelcast.config.SerializationConfig
Portable version will be used to differentiate two versions of the same class that have changes on the class, like adding/removing a field or changing a type of a field.
getPortableVersion(Portable, int) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
 
getPortCount() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getPortCount() - Method in class com.hazelcast.config.NetworkConfig
Returns the maximum number of ports allowed to try to bind on.
getPortCount() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
Returns the maximum number of ports allowed to try to bind on.
getPositiveMillisOrDefault(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty converted to milliseconds if it is positive, otherwise returns its default value.
getPositiveMillisOrDefault(HazelcastProperty, long) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty converted to milliseconds if it is positive, otherwise returns the passed default value.
getPossibleAddresses() - Method in class com.hazelcast.internal.cluster.impl.DiscoveryJoiner
 
getPossibleAddresses() - Method in class com.hazelcast.internal.cluster.impl.TcpIpJoiner
 
getPossibleAddressesForInitialJoin() - Method in class com.hazelcast.internal.cluster.impl.DiscoveryJoiner
 
getPossibleAddressesForInitialJoin() - Method in class com.hazelcast.internal.cluster.impl.TcpIpJoiner
 
getPossibleInetAddressesFor(Inet6Address) - Static method in class com.hazelcast.internal.util.AddressUtil
 
getPossibleSocketAddresses(int, String, int) - Static method in class com.hazelcast.client.util.AddressHelper
 
getPostJoinOperation() - Method in interface com.hazelcast.internal.services.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! The Operation.getPartitionId() method should return a negative value.
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
 
getPostJoinOperations() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
Collects all post-join operations from PostJoinAwareServices.
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
 
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.DefaultMapAggregateMessageTask
 
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.DefaultMapProjectMessageTask
 
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateWithPredicateMessageTask
 
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPagingPredicateMessageTask
 
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPredicateMessageTask
 
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntrySetMessageTask
 
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
 
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
 
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
 
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionWithPredicateMessageTask
 
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesMessageTask
 
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPagingPredicateMessageTask
 
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPredicateMessageTask
 
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
 
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
 
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
 
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
 
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
 
getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
 
getPredicate() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
 
getPredicate() - Method in class com.hazelcast.map.impl.operation.MultipleEntryWithPredicateBackupOperation
 
getPredicate() - Method in class com.hazelcast.map.impl.operation.MultipleEntryWithPredicateOperation
 
getPredicate() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
 
getPredicate() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateBackupOperation
 
getPredicate() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperation
 
getPredicate() - Method in class com.hazelcast.map.impl.query.Query
 
getPredicate() - Method in class com.hazelcast.map.impl.query.QueryEventFilter
 
getPredicate() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
 
getPredicate() - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRequest
 
getPredicate() - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
 
getPredicate() - Method in class com.hazelcast.query.impl.predicates.SqlPredicate
 
getPredicateConfig() - Method in class com.hazelcast.config.QueryCacheConfig
Returns the predicate of QueryCache.
getPredicateConfig() - Method in class com.hazelcast.internal.config.QueryCacheConfigReadOnly
 
getPredicateConfigHolder() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
getPredicates() - Method in class com.hazelcast.query.impl.predicates.AndPredicate
Visitable predicates are treated as effectively immutable, therefore callers should not make any changes to the returned array.
getPredicates() - Method in interface com.hazelcast.query.impl.predicates.CompoundPredicate
An array of predicates which compose this predicate.
getPredicates() - Method in class com.hazelcast.query.impl.predicates.OrPredicate
Visitable predicates are treated as effectively immutable, therefore callers should not make any changes to the returned array.
getPrefetchCount() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
 
getPrefetchCount() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getPrefetchValidityMillis() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
 
getPrefetchValidityMillis() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
getPrefix(URI, ClassLoader) - Static method in class com.hazelcast.cache.CacheUtil
Gets the prefix of cache name without Hazelcast's CacheManager specific prefix HazelcastCacheManager.CACHE_MANAGER_PREFIX.
getPrefix() - Method in class com.hazelcast.config.replacer.EncryptionReplacer
 
getPrefix() - Method in class com.hazelcast.config.replacer.PropertyReplacer
 
getPrefix() - Method in interface com.hazelcast.config.replacer.spi.ConfigReplacer
Variable replacer prefix string.
getPrefix() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getPrefixedCacheName(String, URI, ClassLoader) - Static method in class com.hazelcast.cache.CacheUtil
Gets the cache name with prefix but without Hazelcast's CacheManager specific prefix HazelcastCacheManager.CACHE_MANAGER_PREFIX.
getPrefixedName() - Method in interface com.hazelcast.core.PrefixedDistributedObject
Returns the unique prefixed name for this DistributedObject.
getPrefixes() - Method in class com.hazelcast.config.ClassFilter
Returns unmodifiable set of class name prefixes.
getPreJoinOperation() - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
getPreJoinOperation() - Method in class com.hazelcast.cp.internal.RaftService
 
getPreJoinOperation() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
getPreJoinOperation() - Method in interface com.hazelcast.internal.services.PreJoinAwareService
An operation to be executed on the joining member before it is set as joined.
getPreJoinOperation() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
getPreJoinOperations() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getPreloaderConfig() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.NearCacheConfigHolder
 
getPreloaderConfig() - Method in class com.hazelcast.config.NearCacheConfig
Returns the NearCachePreloaderConfig of this Near Cache.
getPreloaderConfig() - Method in class com.hazelcast.internal.config.NearCacheConfigReadOnly
 
getPreloaderConfig(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
getPreparedXids() - Method in class com.hazelcast.transaction.impl.xa.XAService
 
getPreviousSibling() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getPrincipal() - Method in class com.hazelcast.config.PermissionConfig
 
getPriorityOperationExecutorQueueSize() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
getPriorityOperationExecutorQueueSize() - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
 
getPriorityQueueSize() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
getPriorityQueueSize() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
Deprecated.
getPrivateAddress() - Method in class com.hazelcast.spi.discovery.DiscoveryNode
Returns the private address of the discovered node.
getPrivateAddress() - Method in class com.hazelcast.spi.discovery.SimpleDiscoveryNode
 
getProbe() - Method in interface com.hazelcast.internal.metrics.ProbeAware
Returns the probe.
getProcessablePartitionType() - Method in class com.hazelcast.cache.impl.eviction.CacheClearExpiredRecordsTask
 
getProcessablePartitionType() - Method in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
getProcessablePartitionType() - Method in class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
 
getProgram(String...) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
 
getProgress() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
getProjection() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
 
getProjection() - Method in class com.hazelcast.client.impl.protocol.task.map.DefaultMapAggregateMessageTask
 
getProjection() - Method in class com.hazelcast.client.impl.protocol.task.map.DefaultMapQueryMessageTask
 
getProjection() - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionMessageTask
 
getProjection() - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionWithPredicateMessageTask
 
getProjection() - Method in class com.hazelcast.map.impl.query.Query
 
getProperties() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
getProperties() - Method in class com.hazelcast.client.config.ClientConfig
Gets Properties object
getProperties() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getProperties() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getProperties() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
getProperties() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueueStoreConfigHolder
 
getProperties() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.RingbufferStoreConfigHolder
 
getProperties() - Method in class com.hazelcast.config.AbstractWanPublisherConfig
Returns the WAN publisher properties.
getProperties() - Method in class com.hazelcast.config.AbstractXmlConfigBuilder
Gets the current used properties.
getProperties() - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
Gets the current used properties.
getProperties() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Returns all properties.
getProperties() - Method in class com.hazelcast.config.Config
Returns the properties set on this config instance.
getProperties() - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
getProperties() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
getProperties() - Method in class com.hazelcast.config.LoginModuleConfig
 
getProperties() - Method in class com.hazelcast.config.MapStoreConfig
Returns all the properties
getProperties() - Method in class com.hazelcast.config.MCMutualAuthConfig
Gets all properties.
getProperties() - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
getProperties() - Method in class com.hazelcast.config.PermissionPolicyConfig
 
getProperties() - Method in class com.hazelcast.config.QueueStoreConfig
 
getProperties() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
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.WanConsumerConfig
Returns the properties for the custom WAN consumer.
getProperties() - Method in class com.hazelcast.instance.impl.Node
 
getProperties() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getProperties() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
Returns an immutable copy of the configuration properties.
getProperties() - Method in class com.hazelcast.spi.discovery.DiscoveryNode
Returns a set of unmodifiable properties that are assigned to the discovered node.
getProperties() - Method in class com.hazelcast.spi.discovery.SimpleDiscoveryNode
 
getProperties() - Method in interface com.hazelcast.spi.impl.NodeEngine
Returns the HazelcastProperties.
getProperties() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getProperty(String) - Method in class com.hazelcast.client.config.ClientConfig
Gets a named property already set or from system properties if not exists.
getProperty(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getProperty(String) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Returns property value by the property name.
getProperty(String) - Method in class com.hazelcast.config.Config
Returns the value for a named property.
getProperty(String) - Method in class com.hazelcast.config.MapStoreConfig
Returns the given property
getProperty(String) - Method in class com.hazelcast.config.MCMutualAuthConfig
Gets a property.
getProperty(String) - Method in class com.hazelcast.config.QueueStoreConfig
 
getProperty(String) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getProperty(String) - Method in class com.hazelcast.config.SocketInterceptorConfig
Gets a property.
getProperty(String) - Method in class com.hazelcast.config.SSLConfig
Gets a property.
getProperty(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getProtectOn() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
getProtocolType() - Method in class com.hazelcast.config.EndpointConfig
 
getProtocolType() - Method in class com.hazelcast.config.RestServerEndpointConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.CacheConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.CacheSimpleConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.CollectionConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.MapConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.MultiMapConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.QueueConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.ReplicatedMapConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.RingbufferConfig
 
getProvidedMergeTypes() - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
getProvidedMergeTypes() - Method in interface com.hazelcast.spi.merge.SplitBrainMergeTypeProvider
 
getProviderFilter() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Get current filter or null when no filter is defined.
getProviderMode() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Return the current ProviderMode
getProxyCount() - Method in class com.hazelcast.internal.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.impl.proxyservice.ProxyService
 
getProxyFactoryConfigs() - Method in class com.hazelcast.client.config.ClientConfig
Gets list of ProxyFactoryConfig
getProxyInfos(Collection<ProxyInfo>) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyRegistry
Gets the ProxyInfo of all fully initialized proxies in this registry.
getProxyManager() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getProxyManager() - Method in class com.hazelcast.client.impl.spi.ClientContext
 
getProxyService() - Method in interface com.hazelcast.client.impl.ClientEngine
 
getProxyService() - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
getProxyService() - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
getProxyService() - Method in interface com.hazelcast.spi.impl.NodeEngine
Gets the ProxyService.
getProxyService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getProxyServiceBean() - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
 
getProxyServiceMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getProxySessionManager() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getPublicAddress() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getPublicAddress() - Method in class com.hazelcast.config.NetworkConfig
 
getPublicAddress() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
getPublicAddress(EndpointQualifier) - Method in interface com.hazelcast.instance.AddressPicker
Returns a public address to be advertised to other cluster members and clients.
getPublicAddress() - Method in class com.hazelcast.spi.discovery.DiscoveryNode
Returns the public address of the discovered node if available.
getPublicAddress() - Method in class com.hazelcast.spi.discovery.SimpleDiscoveryNode
 
getPublicAddress() - Method in interface com.hazelcast.spi.MemberAddressProvider
What address should Hazelcast advertise to other members and clients.
getPublicAddress(EndpointQualifier) - Method in interface com.hazelcast.spi.MemberAddressProvider
 
getPublicAddressMap() - Method in interface com.hazelcast.instance.AddressPicker
 
getPublisher(String) - Method in class com.hazelcast.wan.impl.DelegatingWanReplicationScheme
Returns the WanReplicationPublisher with the publisherId or null if it doesn't exist.
getPublisherAddress() - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicMessage
 
getPublisherContext() - Method in class com.hazelcast.client.impl.querycache.ClientQueryCacheContext
 
getPublisherContext() - Method in class com.hazelcast.map.impl.querycache.NodeQueryCacheContext
 
getPublisherContext() - Method in interface com.hazelcast.map.impl.querycache.QueryCacheContext
Returns PublisherContext for this context.
getPublisherId() - Method in class com.hazelcast.config.AbstractWanPublisherConfig
Returns the publisher ID used for identifying the publisher in a WanReplicationConfig.
getPublisherId() - Method in class com.hazelcast.config.CustomWanPublisherConfig
 
getPublisherListenerId() - Method in interface com.hazelcast.map.impl.querycache.subscriber.InternalQueryCache
 
getPublisherListenerId() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
getPublishers() - Method in class com.hazelcast.wan.impl.DelegatingWanReplicationScheme
Returns all WanReplicationPublishers for this delegate
getPublisherState() - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
getPublisherState() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the current WanPublisherState of this publisher.
getPublishingMember() - Method in class com.hazelcast.topic.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.topic.impl.reliable.ReliableTopicMessage
 
getPublishTime() - Method in class com.hazelcast.topic.Message
Return the time when the message is published
getPutOperationCount() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
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
getQualifier() - Method in class com.hazelcast.config.EndpointConfig
 
getQualifier() - Method in class com.hazelcast.config.RestServerEndpointConfig
 
getQualifier() - Method in class com.hazelcast.internal.networking.ServerSocketRegistry.Pair
 
getQueryCache(String) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
getQueryCache(String, Predicate<K, V>, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
getQueryCache(String, MapListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
getQueryCache(String) - Method in interface com.hazelcast.map.IMap
Returns corresponding QueryCache instance for the supplied name or null.
getQueryCache(String, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.IMap
Creates an always up to date snapshot of this IMap according to the supplied parameters.
getQueryCache(String, MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.IMap
Creates an always up to date snapshot of this IMap according to the supplied parameters.
getQueryCache(String) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
getQueryCache(String, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
getQueryCache(String, MapListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
getQueryCacheConfig() - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRequest
 
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.internal.config.MapConfigReadOnly
 
getQueryCacheConfigurator() - Method in class com.hazelcast.client.impl.querycache.ClientQueryCacheContext
 
getQueryCacheConfigurator() - Method in class com.hazelcast.map.impl.querycache.NodeQueryCacheContext
 
getQueryCacheConfigurator() - Method in interface com.hazelcast.map.impl.querycache.QueryCacheContext
Returns QueryCacheConfigurator for this context which will be used to create QueryCacheConfigurator implementations for client or node sides.
getQueryCacheContext() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getQueryCacheContext() - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
getQueryCacheContext() - Method in class com.hazelcast.client.impl.spi.ClientContext
 
getQueryCacheContext() - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getQueryCacheCount(String) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheEndToEndProvider
 
getQueryCacheCount() - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheFactory
 
getQueryCacheEventService() - Method in class com.hazelcast.client.impl.querycache.ClientQueryCacheContext
 
getQueryCacheEventService() - Method in class com.hazelcast.map.impl.querycache.NodeQueryCacheContext
 
getQueryCacheEventService() - Method in interface com.hazelcast.map.impl.querycache.QueryCacheContext
Returns QueryCacheEventService factory for this context which will be used to create QueryCacheEventService implementations for client or node sides.
getQueryCacheFactory() - Method in class com.hazelcast.map.impl.querycache.subscriber.AbstractSubscriberContext
 
getQueryCacheFactory() - Method in interface com.hazelcast.map.impl.querycache.subscriber.SubscriberContext
Returns QueryCacheFactory for this context.
getQueryCacheScheduler() - Method in class com.hazelcast.client.impl.querycache.ClientQueryCacheContext
 
getQueryCacheScheduler() - Method in class com.hazelcast.map.impl.querycache.NodeQueryCacheContext
 
getQueryCacheScheduler() - Method in interface com.hazelcast.map.impl.querycache.QueryCacheContext
Returns QueryCacheScheduler for this context which will be used to create QueryCacheScheduler implementations for client or node sides.
getQueryCount() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
getQueryCount() - Method in class com.hazelcast.monitor.impl.GlobalIndexesStats
 
getQueryCount() - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
getQueryCount() - Method in interface com.hazelcast.monitor.impl.IndexesStats
Returns the number of queries performed on the indexes.
getQueryCount() - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
 
getQueryCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
getQueryCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
getQueryCount() - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Returns the query count.
getQueryCount() - Method in class com.hazelcast.monitor.impl.PartitionIndexesStats
 
getQueryCount() - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
getQueryCount() - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Returns the total number of queries served by the index.
getQueryCount() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the total number of queries served by the index.
getQueryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total number of queries performed on the map.
getQueryEngine(String) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getQueryExecutorMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getQueryOptimizer() - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getQueryResultSizeLimiter() - Method in class com.hazelcast.map.impl.query.QueryEngineImpl
 
getQueue() - Method in class com.hazelcast.client.console.ClientConsoleApp
 
getQueue(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getQueue(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getQueue(String) - Method in class com.hazelcast.client.impl.proxy.txn.TransactionContextProxy
 
getQueue(String) - Method in class com.hazelcast.client.impl.proxy.txn.xa.XATransactionContextProxy
 
getQueue() - Method in class com.hazelcast.console.ConsoleApp
 
getQueue(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed queue instance with the specified name.
getQueue(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getQueue(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getQueue(String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
 
getQueue(String) - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
 
getQueue(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
Returns the transactional queue instance with the specified name.
getQueueCapacity() - Method in class com.hazelcast.config.ExecutorConfig
Gets the queue capacity of the executor task.
getQueueCapacity() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the capacity of the primary and backup queue for WAN replication events.
getQueueConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getQueueConfig(String) - Method in class com.hazelcast.config.Config
Returns the QueueConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getQueueConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getQueueConfigs() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getQueueConfigs() - Method in class com.hazelcast.config.Config
Returns the map of IQueue configurations, mapped by config name.
getQueueConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
getQueueConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Returns all registered queue configurations.
getQueueConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getQueueFullBehavior() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the configured behaviour of this WAN publisher when the WAN queue is full.
getQueueService() - Method in class com.hazelcast.collection.impl.queue.operations.QueueOperation
 
getQueueSize() - Method in class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
getQueueSize() - Method in interface com.hazelcast.internal.util.executor.ManagedExecutorService
 
getQueueSize() - Method in class com.hazelcast.internal.util.executor.NamedThreadPoolExecutor
 
getQueueSize() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
getQueueSize() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
Deprecated.
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.internal.config.QueueConfigReadOnly
 
getRaftAlgorithmConfig() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns configuration options for Hazelcast's Raft consensus algorithm implementation
GetRaftGroupIdsOp - Class in com.hazelcast.cp.internal.raftop.metadata
Returns ids of the Raft groups.
GetRaftGroupIdsOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.GetRaftGroupIdsOp
 
GetRaftGroupOp - Class in com.hazelcast.cp.internal.raftop.metadata
Returns information about the queried Raft group.
GetRaftGroupOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.GetRaftGroupOp
 
GetRaftGroupOp(CPGroupId) - Constructor for class com.hazelcast.cp.internal.raftop.metadata.GetRaftGroupOp
 
getRaftInvocationContext() - Method in class com.hazelcast.cp.internal.RaftInvocationManager
 
getRaftNode(CPGroupId) - Method in class com.hazelcast.cp.internal.RaftService
 
getRandomSamples(int) - Method in class com.hazelcast.internal.util.SampleableConcurrentHashMap
Gets and returns samples as sampleCount.
getRandomSamples(int) - Method in interface com.hazelcast.map.impl.recordstore.Storage
Used for sampling based eviction, returns sampled entries.
getRandomSamples(int) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
getRatio() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
getRatio() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the hit/miss ratio of Near Cache entries owned by this member.
getRawDataInput() - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
getRawDataInput() - Method in interface com.hazelcast.nio.serialization.PortableReader
getRawDataOutput() - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
getRawDataOutput() - Method in interface com.hazelcast.nio.serialization.PortableWriter
After writing portable fields, one can write remaining fields in old fashioned way consecutively at the end of stream.
getReadBatchSize() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Gets the maximum number of items to read in a batch.
getReadBatchSize() - Method in class com.hazelcast.config.ReliableTopicConfig
Gets the maximum number of items to read in a batch.
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.
getReadTimeout() - Method in class com.hazelcast.spring.cache.HazelcastCache
Return cache retrieval timeout in milliseconds
getReadTimeoutMap() - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
Return cache-specific value retrieval timeouts.
getRealmConfig(String) - Method in class com.hazelcast.config.SecurityConfig
 
getRealmConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
getRealmConfigs() - Method in class com.hazelcast.config.SecurityConfig
 
getRealmConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
getRealmCredentialsFactory(String) - Method in class com.hazelcast.config.SecurityConfig
 
getRealmCredentialsFactory(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
getRealmLoginModuleConfigs(String) - Method in class com.hazelcast.config.SecurityConfig
 
getRealmLoginModuleConfigs(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
getReceivedEventCounters(String) - Method in interface com.hazelcast.wan.impl.WanReplicationService
Returns a counter of received and processed WAN replication events.
getReceivedEventCounters(String) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
 
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
getReconnectMode() - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
 
getReconnectMode() - Method in class com.hazelcast.client.impl.spi.impl.AbstractClientInvocationService
 
getRecord(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
getRecord() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
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.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
getRecord(K) - Method in class com.hazelcast.internal.nearcache.impl.store.BaseHeapNearCacheRecordStore
 
getRecord(K) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
Gets the record associated with the given key.
getRecord(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
getRecord() - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
 
getRecord(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
getRecord() - Method in class com.hazelcast.query.impl.QueryableEntry
 
getRecordCollection(NodeEngine) - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
 
getRecordFactoryConstructor() - Method in class com.hazelcast.map.impl.MapContainer
 
getRecordFromEntryView(EntryView) - Method in class com.hazelcast.map.impl.eviction.EvictorImpl
 
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
 
getRecordOrNull(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
getRecordOrNull(Data, long, boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
getRecordOrNull(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Returns live record or null if record is already expired.
getRecords() - Method in class com.hazelcast.multimap.impl.MultiMapMergeContainer
 
getRecords(Comparable) - Method in class com.hazelcast.query.impl.AbstractIndex
 
getRecords(Comparable[]) - Method in class com.hazelcast.query.impl.AbstractIndex
 
getRecords(Comparable, boolean, Comparable, boolean) - Method in class com.hazelcast.query.impl.AbstractIndex
 
getRecords(Comparison, Comparable) - Method in class com.hazelcast.query.impl.AbstractIndex
 
getRecords(Comparable) - Method in interface com.hazelcast.query.impl.Index
Produces a result set containing entries whose attribute values are equal to the given value.
getRecords(Comparable[]) - Method in interface com.hazelcast.query.impl.Index
Produces a result set containing entries whose attribute values are equal to at least one of the given values.
getRecords(Comparable, boolean, Comparable, boolean) - Method in interface com.hazelcast.query.impl.Index
Produces a result set by performing a range query on this index with the range defined by the passed arguments.
getRecords(Comparison, Comparable) - Method in interface com.hazelcast.query.impl.Index
Produces a result set containing entries whose attribute values are satisfy the comparison of the given type with the given value.
getRecords(Comparable) - Method in interface com.hazelcast.query.impl.IndexStore
Obtains entries that have indexed attribute value equal to the given value.
getRecords(Set<Comparable>) - Method in interface com.hazelcast.query.impl.IndexStore
Obtains entries that have indexed attribute value equal to one of the given set of values.
getRecords(Comparison, Comparable) - Method in interface com.hazelcast.query.impl.IndexStore
Obtains entries that have indexed attribute value satisfying the given comparison with the given value.
getRecords(Comparable, boolean, Comparable, boolean) - Method in interface com.hazelcast.query.impl.IndexStore
Obtains entries that have indexed attribute value belonging to the given range.
getRecords(Comparable) - Method in class com.hazelcast.query.impl.OrderedIndexStore
 
getRecords(Set<Comparable>) - Method in class com.hazelcast.query.impl.OrderedIndexStore
 
getRecords(Comparison, Comparable) - Method in class com.hazelcast.query.impl.OrderedIndexStore
 
getRecords(Comparable, boolean, Comparable, boolean) - Method in class com.hazelcast.query.impl.OrderedIndexStore
 
getRecords(Comparable) - Method in class com.hazelcast.query.impl.UnorderedIndexStore
 
getRecords(Set<Comparable>) - Method in class com.hazelcast.query.impl.UnorderedIndexStore
 
getRecords(Comparison, Comparable) - Method in class com.hazelcast.query.impl.UnorderedIndexStore
 
getRecords(Comparable, boolean, Comparable, boolean) - Method in class com.hazelcast.query.impl.UnorderedIndexStore
 
getRecords() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
getRecords() - Method in class com.hazelcast.transaction.impl.TransactionLog
 
getRecords() - Method in class com.hazelcast.transaction.impl.xa.XATransactionDTO
 
getRecordsSynced() - Method in class com.hazelcast.internal.management.events.WanSyncProgressUpdateEvent
 
getRecordsSynced() - Method in interface com.hazelcast.wan.WanSyncStats
Returns the number of the records synchronized.
getRecordState() - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
getRecordState() - Method in interface com.hazelcast.internal.nearcache.NearCacheRecord
 
getRecordStorageMemoryCost(R) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
getRecordStorageMemoryCost(NearCacheDataRecord) - Method in class com.hazelcast.internal.nearcache.impl.store.NearCacheDataRecordStore
 
getRecordStorageMemoryCost(NearCacheObjectRecord) - Method in class com.hazelcast.internal.nearcache.impl.store.NearCacheObjectRecordStore
 
getRecordStore(String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
getRecordStore(String) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
Returns a cache record store with the prefixed cacheNameWithPrefix or null if one doesn't exist.
getRecordStore(String, int) - Method in interface com.hazelcast.cache.impl.ICacheService
Returns a cache record store with the prefixed cacheNameWithPrefix and partition ID or null if one doesn't exist.
getRecordStore(int, String) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getRecordStore(int, String, boolean) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getRecordStore(String) - Method in class com.hazelcast.map.impl.PartitionContainer
 
getRecordStore(String, boolean) - Method in class com.hazelcast.map.impl.PartitionContainer
 
getRecordStore(String) - Method in class com.hazelcast.replicatedmap.impl.PartitionContainer
 
getRecordStoreForHotRestart(String) - Method in class com.hazelcast.map.impl.PartitionContainer
 
getRecordValue(R) - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
getReferenceCallId() - Method in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
getRegion() - Method in class com.hazelcast.config.AwsConfig
getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.AbstractRemoveListenerMessageTask
 
getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
 
getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
 
getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
 
getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveListenerMessageTask
 
getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveEntryListenerMessageTask
 
getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemovePartitionLostListenerMessageTask
 
getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
 
getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
 
getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
 
getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
 
getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
 
getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveListenerMessageTask
 
getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicRemoveMessageListenerMessageTask
 
getRegistrationIdMap() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceSegment
Returns the map from registration ID to the listener registration.
getRegistrations() - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheEventService
 
getRegistrations() - Method in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
getRegistrations(String) - Method in class com.hazelcast.map.impl.event.MapEventPublisherImpl
Return all listener registrations for the map with mapName.
getRegistrations(String, String) - Method in interface com.hazelcast.spi.impl.eventservice.EventService
Returns all registrations belonging to the given service and topic.
getRegistrations(String, String) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
Returns all registrations belonging to the given service and topic.
getRegistrations(String, boolean) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceSegment
Returns the Registrations for the event topic.
getRegistrations() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceSegment
 
getRegistrationsAsArray(String, String) - Method in interface com.hazelcast.spi.impl.eventservice.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
 
getRegistryOrNull(CPGroupId) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
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
 
getReliableLocalTopicStats(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
getReliableLocalTopicStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
getReliableTopic(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getReliableTopic(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getReliableTopic(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the reliable topic instance with the specified name.
getReliableTopic(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getReliableTopic(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getReliableTopicConfig(String) - Method in class com.hazelcast.client.config.ClientConfig
Gets the ClientReliableTopicConfig for a given reliable topic name.
getReliableTopicConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getReliableTopicConfig(String) - Method in class com.hazelcast.config.Config
Returns the ReliableTopicConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getReliableTopicConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getReliableTopicConfigMap() - Method in class com.hazelcast.client.config.ClientConfig
Returns the map of reliable topic configurations, mapped by config name.
getReliableTopicConfigs() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getReliableTopicConfigs() - Method in class com.hazelcast.config.Config
Returns the map of reliable topic configurations, mapped by config name.
getReliableTopicConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
getReliableTopicConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Returns all registered reliable topic configurations.
getReliableTopicConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getRemainingCount(CPGroupId, String) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchService
 
getRemainingDataLoadTimeMillis() - Method in class com.hazelcast.internal.management.dto.ClusterHotRestartStatusDTO
 
getRemainingLeaseTime() - Method in interface com.hazelcast.internal.locksupport.LockResource
 
getRemainingLeaseTime(Data) - Method in interface com.hazelcast.internal.locksupport.LockStore
Return the remaining lease time for a specific key.
getRemainingLeaseTime(Data) - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
getRemainingLeaseTime(Data) - Method in class com.hazelcast.internal.locksupport.LockStoreProxy
 
getRemainingMigrations() - Method in class com.hazelcast.internal.partition.impl.MigrationStats
Returns the number of remaining migrations on the latest repartitioning round.
getRemainingMigrations() - Method in class com.hazelcast.internal.partition.MigrationStateImpl
 
getRemainingMigrations() - Method in interface com.hazelcast.partition.MigrationState
Returns the number of remaining migrations in the migration plan.
getRemainingQueueCapacity() - Method in class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
getRemainingQueueCapacity() - Method in interface com.hazelcast.internal.util.executor.ManagedExecutorService
 
getRemainingQueueCapacity() - Method in class com.hazelcast.internal.util.executor.NamedThreadPoolExecutor
 
getRemainingTime() - Method in class com.hazelcast.internal.util.LockGuard
 
getRemainingValidationTimeMillis() - Method in class com.hazelcast.internal.management.dto.ClusterHotRestartStatusDTO
 
getRemoteCertificates() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
getRemoteCertificates() - Method in interface com.hazelcast.internal.nio.Connection
Returns certificate chain of the remote party.
getRemoteCertificates() - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
getRemoteOperationsCount() - Method in class com.hazelcast.internal.jmx.OperationServiceMBean
 
getRemoteOperationsCount() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
getRemoteOperationsCount() - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
 
getRemoteSocketAddress() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
getRemoteSocketAddress() - Method in interface com.hazelcast.internal.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.internal.nio.tcp.TcpIpConnection
 
getRemoveCount() - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
getRemoveCount() - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
 
getRemoveCount() - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Returns the remove count.
getRemoveCount() - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
getRemoveCount() - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Returns the number of remove operations performed on the index.
getRemoveCount() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the number of remove operations performed on the index.
getRemoveCount() - Method in class com.hazelcast.wan.DistributedServiceWanEventCounters.DistributedObjectWanEventCounters
Returns the number of entry remove events
getRemoveOperationCount() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
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
getRepairingTask(String) - Method in class com.hazelcast.client.impl.spi.ClientContext
 
getRepairingTask() - Method in class com.hazelcast.map.impl.nearcache.MapNearCacheManager
 
getReplacement(String) - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
 
getReplacement(String) - Method in class com.hazelcast.config.replacer.PropertyReplacer
 
getReplacement(String) - Method in interface com.hazelcast.config.replacer.spi.ConfigReplacer
Provides String which should be used as a variable replacement for given masked value.
getReplica(int) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionImpl
 
getReplica(int) - Method in interface com.hazelcast.internal.partition.InternalPartition
Returns the partition replica assigned to the replica index.
getReplica(int, int) - Method in class com.hazelcast.internal.partition.PartitionTableView
 
getReplicaAddress(int) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionImpl
 
getReplicaAddress(int) - Method in interface com.hazelcast.spi.partition.IPartition
Returns the address of the replica.
getReplicaCount() - Method in class com.hazelcast.config.PNCounterConfig
Returns the number of replicas on which state for this PN counter will be kept.
getReplicaIndex(PartitionReplica) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionImpl
 
getReplicaIndex(PartitionReplica) - Method in interface com.hazelcast.internal.partition.InternalPartition
Return the index of partition replica for this partition.
getReplicaIndex() - Method in class com.hazelcast.internal.partition.ReplicaMigrationEventImpl
 
getReplicaIndex() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
Returns the index of the partition replica.
getReplicaIndex() - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Gets the replicaIndex.
getReplicaIndex() - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
getReplicaIndex() - Method in class com.hazelcast.spi.partition.PartitionReplicationEvent
Gets the replica index.
getReplicaManager() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getReplicas(int) - Method in class com.hazelcast.internal.partition.PartitionTableView
 
getReplicatedMap(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getReplicatedMap(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getReplicatedMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the replicated map instance with the specified name.
getReplicatedMap(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getReplicatedMap(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getReplicatedMapConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getReplicatedMapConfig(String) - Method in class com.hazelcast.config.Config
Returns the ReplicatedMapConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getReplicatedMapConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getReplicatedMapConfig(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
getReplicatedMapConfigs() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getReplicatedMapConfigs() - Method in class com.hazelcast.config.Config
Returns the map of ReplicatedMap configurations, mapped by config name.
getReplicatedMapConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
getReplicatedMapConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Returns all registered replicated map configurations.
getReplicatedMapConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getReplicatedMapStats() - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
getReplicatedMapStats() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
getReplicatedMapStats() - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Returns LocalReplicatedMapStats for this replicated map.
getReplicatedRecord(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
getReplicatedRecord(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
getReplicatedRecordStore(String, boolean, Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
getReplicatedRecordStore(String, boolean, int) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
getReplicationEventCount() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
getReplicationEventCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
getReplicationEventCount() - Method in interface com.hazelcast.monitor.LocalReplicatedMapStats
Deprecated.
replication is no more handled by event system.
getReplicationPeriodMillis() - Method in class com.hazelcast.config.CRDTReplicationConfig
Returns the period between two replications of CRDT states in milliseconds.
getRequest() - Method in class com.hazelcast.internal.cluster.impl.operations.JoinRequestOp
 
getRequestId() - Method in class com.hazelcast.internal.ascii.AbstractTextCommand
 
getRequestId() - Method in interface com.hazelcast.internal.ascii.TextCommand
 
getRequiredMember() - Method in class com.hazelcast.config.TcpIpConfig
Gets the required member.
getRequiredPermission() - Method in interface com.hazelcast.client.impl.client.SecureRequest
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.AddBackupListenerMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionListenerMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
 
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.CacheAddNearCacheInvalidationListenerTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheContainsKeyMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheCreateConfigMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEntryProcessorMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalReadTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalSubscribeTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheFetchNearCacheInvalidationMetadataTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAllMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndRemoveMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndReplaceMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetConfigMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateEntriesMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutAllMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutIfAbsentMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheReplaceMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSetExpiryPolicyMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSizeMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.Pre38CacheAddInvalidationListenerTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorAddMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorEstimateMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.ClientStatisticsMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterAddMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetConfiguredReplicaCountMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxiesMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.DeployClassesMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AbstractAddConfigMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorDisposeResultMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorIsShutdownMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveAndDisposeResultMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveResultMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorShutdownMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorSubmitToPartitionMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnAddressMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnPartitionMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.IsFailoverSupportedMessageTask
 
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.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.AbstractMapSetMessageTask
 
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.MapAddListenerMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAggregateWithPredicateMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsMessageTask
 
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.MapDestroyCacheMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntrySetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEventJournalReadTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEventJournalSubscribeTask
 
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.MapFetchEntriesMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchKeysMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchNearCacheInvalidationMetadataTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchWithQueryMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetEntryViewMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapMadePublishableMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapProjectionWithPredicateMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateWithValueMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveAllMessageTask
 
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.MapSetReadCursorMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetTtlMessageTask
 
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.metrics.ReadMetricsMessageTask
 
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.MultiMapDeleteMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapGetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapPutMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValueCountMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddAllMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueClearMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRemoveAllMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRetainAllMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsAllMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMaxSizeMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIsEmptyMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIteratorMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueOfferMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePeekMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePollMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePutMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemainingCapacityMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueSizeMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueTakeMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddAllMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferCapacityMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferHeadSequenceMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadManyMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadOneMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferRemainingCapacityMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferSizeMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferTailSequenceMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorGetAllScheduledMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorShutdownMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToAddressMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToPartitionMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromAddressMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromPartitionMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromAddressMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromPartitionMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromAddressMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromPartitionMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromAddressMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromPartitionMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromAddressMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromPartitionMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromAddressMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromPartitionMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromAddressMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromPartitionMessageTask
 
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.cp.internal.datastructures.atomiclong.client.AddAndGetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.AlterMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.ApplyMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.CompareAndSetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetAndAddMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetAndSetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.ApplyMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.CompareAndSetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.ContainsMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.GetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.SetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.AwaitMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.CountDownMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.GetCountMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.GetRoundMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.TrySetCountMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.GetLockOwnershipStateMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.LockMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.TryLockMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.UnlockMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.AcquirePermitsMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.AvailablePermitsMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.ChangePermitsMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.DrainPermitsMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.GetSemaphoreTypeMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.InitSemaphoreMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.ReleasePermitsMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.spi.client.CreateRaftGroupMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.cp.internal.datastructures.spi.client.DestroyRaftObjectMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.flakeidgen.impl.client.NewIdBatchMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterAddAndGetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterDecrementAndGetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndAddMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndIncrementMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndSetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterIncrementAndGetMessageTask
 
getRequiredPermission() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterSetMessageTask
 
getReservedCapacityCountPerTxnId() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.TxnReservedCapacityCounter
Returns reserved capacity counts of all transactions which happened on this record store.
getReservedCapacityCountPerTxnId() - Method in class com.hazelcast.map.impl.mapstore.writebehind.TxnReservedCapacityCounterImpl
 
getResourceFactory() - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
getResourceOrNull(String) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
getResponse() - Method in class com.hazelcast.cache.impl.CacheClearResponse
 
getResponse() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalSubscribeOperation
 
getResponse() - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
Deprecated.
 
getResponse() - Method in class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
 
getResponse() - Method in class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation
 
getResponse() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
 
getResponse() - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperation
 
getResponse() - Method in class com.hazelcast.cache.impl.operation.CacheSetExpiryPolicyOperation
 
getResponse() - Method in class com.hazelcast.cache.impl.operation.KeyBasedCacheOperation
 
getResponse() - Method in class com.hazelcast.cardinality.impl.operations.EstimateOperation
 
getResponse() - Method in class com.hazelcast.client.impl.ClientBackupAwareResponse
 
getResponse() - Method in class com.hazelcast.client.impl.operations.GetConnectedClientsOperation
 
getResponse() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsOperation
 
getResponse() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsOperation
 
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.cp.internal.operation.GetLeadedGroupsOp
 
getResponse() - Method in class com.hazelcast.cp.internal.operation.integration.AsyncRaftOp
 
getResponse() - Method in class com.hazelcast.cp.internal.operation.unsafe.AbstractUnsafeRaftOp
 
getResponse() - Method in class com.hazelcast.durableexecutor.impl.operations.RetrieveAndDisposeResultOperation
 
getResponse() - Method in class com.hazelcast.durableexecutor.impl.operations.RetrieveResultOperation
 
getResponse() - Method in class com.hazelcast.durableexecutor.impl.operations.TaskOperation
 
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.cluster.impl.operations.CommitClusterStateOp
 
getResponse() - Method in class com.hazelcast.internal.cluster.impl.operations.FetchMembersViewOp
 
getResponse() - Method in class com.hazelcast.internal.cluster.impl.operations.JoinMastershipClaimOp
 
getResponse() - Method in class com.hazelcast.internal.cluster.impl.operations.PromoteLiteMemberOp
 
getResponse() - Method in class com.hazelcast.internal.cluster.impl.operations.RollbackClusterStateOp
 
getResponse() - Method in class com.hazelcast.internal.cluster.impl.operations.SplitBrainMergeValidationOp
 
getResponse() - Method in class com.hazelcast.internal.crdt.pncounter.operations.AddOperation
 
getResponse() - Method in class com.hazelcast.internal.crdt.pncounter.operations.GetOperation
 
getResponse() - Method in class com.hazelcast.internal.journal.EventJournalReadOperation
 
getResponse() - Method in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
getResponse() - Method in class com.hazelcast.internal.longregister.operations.AddAndGetOperation
 
getResponse() - Method in class com.hazelcast.internal.longregister.operations.GetAndAddOperation
 
getResponse() - Method in class com.hazelcast.internal.longregister.operations.GetAndSetOperation
 
getResponse() - Method in class com.hazelcast.internal.longregister.operations.GetOperation
 
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.metrics.managementcenter.ReadMetricsOperation
 
getResponse() - Method in class com.hazelcast.internal.partition.operation.AssignPartitions
 
getResponse() - Method in class com.hazelcast.internal.partition.operation.FetchPartitionStateOperation
 
getResponse() - Method in class com.hazelcast.internal.partition.operation.HasOngoingMigration
 
getResponse() - Method in class com.hazelcast.internal.partition.operation.MigrationCommitOperation
 
getResponse() - Method in class com.hazelcast.internal.partition.operation.PartitionBackupReplicaAntiEntropyOperation
 
getResponse() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRequest
 
getResponse() - Method in class com.hazelcast.internal.partition.operation.PartitionStateOperation
 
getResponse() - Method in class com.hazelcast.internal.partition.operation.PartitionStateVersionCheckOperation
 
getResponse() - Method in class com.hazelcast.internal.partition.operation.PromotionCommitOperation
 
getResponse() - Method in class com.hazelcast.internal.partition.operation.PublishCompletedMigrationsOperation
 
getResponse() - Method in class com.hazelcast.internal.partition.operation.SafeStateCheckOperation
 
getResponse() - Method in class com.hazelcast.internal.usercodedeployment.impl.operation.ClassDataFinderOperation
 
getResponse() - Method in class com.hazelcast.internal.util.LocalRetryableExecution
The response of the operation execution.
getResponse() - Method in class com.hazelcast.map.impl.journal.MapEventJournalSubscribeOperation
 
getResponse() - Method in class com.hazelcast.map.impl.operation.AddIndexBackupOperation
 
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.AwaitMapFlushOperation
 
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.EntryOperation
 
getResponse() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
 
getResponse() - Method in class com.hazelcast.map.impl.operation.EvictBackupOperation
 
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.IsKeyLoadFinishedOperation
 
getResponse() - Method in class com.hazelcast.map.impl.operation.IsPartitionLoadedOperation
 
getResponse() - Method in class com.hazelcast.map.impl.operation.MapFetchEntriesOperation
 
getResponse() - Method in class com.hazelcast.map.impl.operation.MapFetchKeysOperation
 
getResponse() - Method in class com.hazelcast.map.impl.operation.MapFetchWithQueryOperation
 
getResponse() - Method in class com.hazelcast.map.impl.operation.MapFlushOperation
 
getResponse() - Method in class com.hazelcast.map.impl.operation.MapGetInvalidationMetaDataOperation
 
getResponse() - Method in class com.hazelcast.map.impl.operation.MapIsEmptyOperation
 
getResponse() - Method in class com.hazelcast.map.impl.operation.MapSizeOperation
 
getResponse() - Method in class com.hazelcast.map.impl.operation.MergeOperation
 
getResponse() - Method in class com.hazelcast.map.impl.operation.MultipleEntryBackupOperation
 
getResponse() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
 
getResponse() - Method in class com.hazelcast.map.impl.operation.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.PutWithExpiryOperation
 
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.SetTtlOperation
 
getResponse() - Method in class com.hazelcast.map.impl.operation.TriggerLoadIfNeededOperation
 
getResponse() - Method in class com.hazelcast.map.impl.operation.TryPutOperation
 
getResponse() - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
 
getResponse() - Method in class com.hazelcast.map.impl.query.QueryOperation
 
getResponse() - Method in class com.hazelcast.map.impl.query.QueryPartitionOperation
 
getResponse() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.DestroyQueryCacheOperation
 
getResponse() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.MadePublishableOperation
 
getResponse() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.PublisherCreateOperation
 
getResponse() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.ReadAndResetAccumulatorOperation
 
getResponse() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.SetReadCursorOperation
 
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.multimap.impl.operations.AbstractMultiMapOperation
 
getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
 
getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperation
 
getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsKeyOperation
 
getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsValueOperation
 
getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.EntrySetOperation
 
getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.GetOperation
 
getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.IsEmptyOperation
 
getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.KeySetOperation
 
getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.MergeOperation
 
getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.SizeOperation
 
getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.ValuesOperation
 
getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.VersionResponsePair
 
getResponse() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
 
getResponse() - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
 
getResponse() - Method in class com.hazelcast.ringbuffer.impl.operations.GenericOperation
 
getResponse() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
 
getResponse() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
 
getResponse() - Method in class com.hazelcast.scheduledexecutor.impl.operations.CancelTaskOperation
 
getResponse() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnMemberOperation
 
getResponse() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnPartitionOperation
 
getResponse() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetDelayOperation
 
getResponse() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetResultOperation
 
getResponse() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetStatisticsOperation
 
getResponse() - Method in class com.hazelcast.scheduledexecutor.impl.operations.IsCanceledOperation
 
getResponse() - Method in class com.hazelcast.scheduledexecutor.impl.operations.IsDoneOperation
 
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.Operation
Called if and only if Operation.returnsResponse() returned true, shortly after Operation.run() returns.
getResponse() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.DistributedObjectDestroyOperation
 
getResponse() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.InitializeDistributedObjectOperation
 
getResponse() - Method in class com.hazelcast.transaction.impl.operations.BroadcastTxRollbackOperation
 
getResponse() - Method in class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
 
getResponse() - Method in class com.hazelcast.transaction.impl.operations.ReplicateTxBackupLogOperation
 
getResponse() - Method in class com.hazelcast.transaction.impl.operations.RollbackTxBackupLogOperation
 
getResponse() - Method in class com.hazelcast.transaction.impl.xa.operations.CollectRemoteTransactionsOperation
 
getResponseHandler() - Method in interface com.hazelcast.client.impl.spi.ClientInvocationService
 
getResponseHandler() - Method in class com.hazelcast.client.impl.spi.impl.AbstractClientInvocationService
 
getResponseQueueSize() - Method in class com.hazelcast.internal.jmx.OperationServiceMBean
 
getResponseQueueSize() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
getResponseQueueSize() - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Returns the size of the response queue.
getResponseTimeoutMillis() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the duration in milliseconds for the wait time before retrying to send the events to target cluster again in case the acknowledgement has not arrived.
getRestApiConfig() - Method in class com.hazelcast.config.NetworkConfig
 
getRestApiConfig() - Method in interface com.hazelcast.internal.nio.IOService
Returns initialized RestApiConfig for the node.
getRestApiConfig() - Method in class com.hazelcast.internal.nio.NodeIOService
 
getRestEndpointConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
getResult() - Method in class com.hazelcast.map.impl.operation.EntryOperator
 
getResult() - Method in class com.hazelcast.map.impl.query.ResultSegment
 
getResult() - Method in class com.hazelcast.query.impl.DefaultValueCollector
 
GetResultOperation<V> - Class in com.hazelcast.scheduledexecutor.impl.operations
 
GetResultOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetResultOperation
 
GetResultOperation(ScheduledTaskHandler) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetResultOperation
 
getResultProcessorRegistry() - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getResults() - Method in class com.hazelcast.query.impl.getters.ImmutableMultiResult
 
getResults() - Method in class com.hazelcast.query.impl.getters.MultiResult
 
getResults() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation.PartitionResponse
 
getResultType() - Method in class com.hazelcast.map.impl.query.Query
 
getRetentionSeconds() - Method in class com.hazelcast.config.MetricsConfig
Returns the number of seconds the metrics will be retained on the instance.
getRetryCount() - Method in class com.hazelcast.internal.util.iterator.RestartingMemberIterator
 
getReturnValue() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskResult
 
getRevision() - Method in class com.hazelcast.instance.BuildInfo
 
getRevision() - Method in class com.hazelcast.instance.JetBuildInfo
 
getRightChildOrder(int) - Static method in class com.hazelcast.wan.impl.merkletree.MerkleTreeUtil
Returns the breadth-first order of the right child node of the node with nodeOrder
getRingbuffer(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getRingbuffer(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getRingbuffer() - Method in class com.hazelcast.client.impl.proxy.ClientReliableTopicProxy
 
getRingbuffer(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed Ringbuffer instance with the specified name.
getRingBuffer() - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorContainer
 
getRingbuffer(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getRingbuffer(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getRingbuffer() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
Returns the ringbuffer containing the actual items.
getRingbufferConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getRingbufferConfig(String) - Method in class com.hazelcast.config.Config
Returns the RingbufferConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getRingbufferConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getRingbufferConfig(String) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
getRingbufferConfigs() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getRingbufferConfigs() - Method in class com.hazelcast.config.Config
Returns the map of Ringbuffer configurations, mapped by config name.
getRingbufferConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
getRingbufferConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Returns all registered ringbuffer configurations.
getRingbufferConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getRingbufferNamespace(String) - Static method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
getRingbufferPartitionId(String) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
getRingbufferStoreConfig() - Method in class com.hazelcast.config.RingbufferConfig
Get the RingbufferStore (load and store ringbuffer items from/to a database) configuration.
getRingbufferStoreConfig() - Method in class com.hazelcast.internal.config.RingbufferConfigReadOnly
 
getRingEmptyWaitNotifyKey() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
Gets the wait/notify key for the blocking operations of reading from the ring buffer.
getRoleAttribute() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
 
getRoleContext() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getRoleFilter() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getRoleMappingAttribute() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getRoleMappingMode() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getRoleMappingMode(String) - Static method in enum com.hazelcast.config.security.LdapRoleMappingMode
 
getRoleNameAttribute() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getRoleRecursionMaxDepth() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getRoleSearchScope() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getRound(CPGroupId, String) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchService
 
GetRoundMessageTask - Class in com.hazelcast.cp.internal.datastructures.countdownlatch.client
Client message task for GetRoundOp
GetRoundMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.client.GetRoundMessageTask
 
GetRoundOp - Class in com.hazelcast.cp.internal.datastructures.countdownlatch.operation
Operation used by ICountDownLatch.countDown()
GetRoundOp() - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.GetRoundOp
 
GetRoundOp(String) - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.GetRoundOp
 
getRows() - Method in class com.hazelcast.map.impl.query.QueryResult
 
getRunnable() - Method in class com.hazelcast.executor.impl.RunnableAdapter
 
getRunnable() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledRunnableAdapter
 
getRunningOperationCount() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
getRunningOperationCount() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
Deprecated.
getRunningOperationsCount() - Method in class com.hazelcast.internal.jmx.OperationServiceMBean
 
getRunningOperationsCount() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
getRunningOperationsCount() - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
 
getRuntimeProps() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
getRuntimeProps() - Method in interface com.hazelcast.monitor.MemberState
 
getSalt() - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
Returns the salt.
getSamples(RecordStore) - Method in class com.hazelcast.map.impl.eviction.EvictorImpl
 
getScheduledDelayMillis() - Method in class com.hazelcast.internal.util.scheduler.ScheduledEntry
 
getScheduledDurable(String) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
getScheduledDurable(String) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
getScheduledExecutorConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getScheduledExecutorConfig(String) - Method in class com.hazelcast.config.Config
Returns the ScheduledExecutorConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getScheduledExecutorConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getScheduledExecutorConfigs() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getScheduledExecutorConfigs() - Method in class com.hazelcast.config.Config
Returns the map of scheduled executor configurations, mapped by config name.
getScheduledExecutorConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
getScheduledExecutorConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Returns all registered scheduled executor configurations.
getScheduledExecutorConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getScheduledExecutorMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getScheduledExecutorService(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getScheduledExecutorService(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getScheduledExecutorService(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the IScheduledExecutorService scheduled executor service for the given name.
getScheduledExecutorService(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getScheduledExecutorService(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getScheduledExecutorService() - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
getScheduledFuture(ScheduledTaskHandler) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
getScheduledFuture(ScheduledTaskHandler) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
getScheduledFuture(ScheduledTaskHandler) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates a new IScheduledFuture from the given handler.
getScheduledReplicaSyncRequests() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
getScheduleId() - Method in class com.hazelcast.internal.util.scheduler.ScheduledEntry
 
getScheduler() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
 
getSchedulerName() - Method in class com.hazelcast.scheduledexecutor.impl.operations.AbstractSchedulerOperation
 
getSchedulerName() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
 
getSchedulerName() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Return the name of the ScheduledExecutor this tasks is running on.
getSchemaTypeInfo() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getScopedHost() - Method in class com.hazelcast.cluster.Address
 
getScopedHostName(AddressUtil.AddressHolder) - Static method in class com.hazelcast.client.util.AddressHelper
 
getScopeId() - Method in class com.hazelcast.cluster.Address
 
getScopeId() - Method in class com.hazelcast.internal.util.AddressUtil.AddressHolder
 
getScriptEngine() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
 
getScriptEngineManager() - Static method in class com.hazelcast.internal.management.ScriptEngineManagerContext
 
getSearchScope(String) - Static method in enum com.hazelcast.config.security.LdapSearchScope
 
getSeconds(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty converted to seconds.
getSecretKey() - Method in class com.hazelcast.config.AwsConfig
getSecretPath() - Method in class com.hazelcast.config.VaultSecureStoreConfig
Returns the Vault secret path.
getSecure() - Static method in class com.hazelcast.internal.util.ThreadLocalRandomProvider
Returns the current thread's SecureRandom.
getSecureStore(SecureStoreConfig) - Method in interface com.hazelcast.spi.impl.securestore.SecureStoreFactory
Returns a SecureStore implementation for the provided configuration.
getSecureStoreConfig() - Method in class com.hazelcast.config.EncryptionAtRestConfig
Returns the Secure Store configuration.
getSecurityConfig() - Method in class com.hazelcast.client.config.ClientConfig
Gets ClientSecurityConfig object which allows client credentials configuration.
getSecurityConfig() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getSecurityConfig() - Method in class com.hazelcast.config.Config
Returns the security configuration for this hazelcast instance.
getSecurityConfig() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getSecurityContext() - Method in interface com.hazelcast.client.impl.ClientEngine
 
getSecurityContext() - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
getSecurityContext() - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
getSecurityContext() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
getSecurityContext() - Method in interface com.hazelcast.instance.impl.NodeExtension
Returns SecurityContext for this Node if available, otherwise returns null.
getSecurityGroupName() - Method in class com.hazelcast.config.AwsConfig
getSecurityInterceptorConfigs() - Method in class com.hazelcast.config.SecurityConfig
 
getSecurityInterceptorConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
getSecurityService() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
getSecurityService() - Method in class com.hazelcast.instance.impl.Node
 
getSecurityService() - Method in interface com.hazelcast.instance.impl.NodeExtension
 
getSeed() - Method in class com.hazelcast.cp.internal.RaftGroupId
 
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
Returns the EventServiceSegment for the service.
getSelector() - Method in class com.hazelcast.internal.networking.nio.NioThread
Gets the Selector
getSemaphore(String) - Method in class com.hazelcast.client.cp.internal.CPSubsystemImpl
 
getSemaphore(String) - Method in interface com.hazelcast.cp.CPSubsystem
Returns a proxy for an ISemaphore instance created on CP Subsystem.
getSemaphore(String) - Method in class com.hazelcast.cp.internal.CPSubsystemImpl
 
getSemaphoreConfigs() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the map of CP ISemaphore configurations
GetSemaphoreTypeMessageTask - Class in com.hazelcast.cp.internal.datastructures.semaphore.client
Client message task for querying semaphore JDK compatibility
GetSemaphoreTypeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.client.GetSemaphoreTypeMessageTask
 
getSendConnection() - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocation
 
getSendConnectionOrWait() - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocation
 
getSentCacheEventCounter() - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
getSentCacheEventCounter() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the counter for the successfully transfered cache WAN events.
getSentEventCounters(String, String, String) - Method in interface com.hazelcast.wan.impl.WanReplicationService
Returns a counter of sent and processed WAN replication events.
getSentEventCounters(String, String, String) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
 
getSentMapEventCounter() - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
getSentMapEventCounter() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the counter for the successfully transfered map WAN events.
getSequence() - Method in class com.hazelcast.durableexecutor.impl.TaskRingBuffer.DurableIterator
 
getSequence() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidation
 
getSequence() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataContainer
 
getSequence() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntry
 
getSequence() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore.Sequence
 
getSequence() - Method in class com.hazelcast.map.impl.querycache.event.BatchEventData
 
getSequence() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
getSequence() - Method in class com.hazelcast.map.impl.querycache.event.sequence.DefaultPartitionSequencer
 
getSequence(int) - Method in class com.hazelcast.map.impl.querycache.event.sequence.DefaultSubscriberSequencerProvider
 
getSequence() - Method in interface com.hazelcast.map.impl.querycache.event.sequence.PartitionSequencer
Returns current sequence number of the partition.
getSequence() - Method in interface com.hazelcast.map.impl.querycache.event.sequence.Sequenced
Returns the sequence number.
getSequence(int) - Method in interface com.hazelcast.map.impl.querycache.event.sequence.SubscriberSequencerProvider
Returns partition's current sequence number.
getSequence() - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
getSequence() - Method in interface com.hazelcast.map.impl.record.Record
Only used for Hot Restart, HDRecord
getSequence(int) - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
 
getSequence(int) - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
 
getSequence(int) - Method in interface com.hazelcast.ringbuffer.ReadResultSet
Return the sequence number for the item at the given index.
getSequenceGenerators() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataGenerator
 
getSequenceToFlush() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
getSerializationConfig() - Method in class com.hazelcast.client.config.ClientConfig
getSerializationConfig() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getSerializationConfig() - Method in class com.hazelcast.config.Config
Returns the serialization configuration for this hazelcast instance.
getSerializationConfig() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getSerializationService() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getSerializationService() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getSerializationService() - Method in class com.hazelcast.client.impl.querycache.ClientQueryCacheContext
 
getSerializationService() - Method in class com.hazelcast.client.impl.spi.ClientContext
 
getSerializationService() - Method in class com.hazelcast.client.impl.spi.ClientProxy
 
getSerializationService() - Method in class com.hazelcast.client.map.impl.ClientMapPartitionIterator
 
getSerializationService() - Method in class com.hazelcast.client.map.impl.ClientMapQueryPartitionIterator
 
getSerializationService() - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getSerializationService() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getSerializationService() - Method in class com.hazelcast.instance.impl.Node
 
getSerializationService() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
 
getSerializationService() - Method in interface com.hazelcast.internal.nio.IOService
 
getSerializationService() - Method in class com.hazelcast.internal.nio.NodeIOService
 
getSerializationService() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
getSerializationService() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
getSerializationService() - Method in class com.hazelcast.map.impl.iterator.AbstractMapPartitionIterator
 
getSerializationService() - Method in class com.hazelcast.map.impl.iterator.AbstractMapQueryPartitionIterator
 
getSerializationService() - Method in class com.hazelcast.map.impl.iterator.MapPartitionIterator
 
getSerializationService() - Method in class com.hazelcast.map.impl.iterator.MapQueryPartitionIterator
 
getSerializationService() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
 
getSerializationService() - Method in class com.hazelcast.map.impl.querycache.NodeQueryCacheContext
 
getSerializationService() - Method in interface com.hazelcast.map.impl.querycache.QueryCacheContext
Returns InternalSerializationService for this context.
getSerializationService() - Method in class com.hazelcast.multimap.impl.MultiMapService
 
getSerializationService() - Method in interface com.hazelcast.nio.ObjectDataInput
 
getSerializationService() - Method in interface com.hazelcast.nio.ObjectDataOutput
 
getSerializationService() - Method in class com.hazelcast.spi.impl.merge.AbstractMergeRunnable
 
getSerializationService() - Method in interface com.hazelcast.spi.impl.NodeEngine
Gets the SerializationService.
getSerializationService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getSerializationService() - Method in interface com.hazelcast.spi.impl.SerializationServiceSupport
 
getSerializationType() - Method in interface com.hazelcast.nio.serialization.SerializerHook
Returns the actual class type of the serialized object
getSerializationVersion() - Method in class com.hazelcast.instance.BuildInfo
 
getSerializedValue(SerializationService) - Method in class com.hazelcast.cache.impl.DeferredValue
 
getSerializerConfigs() - Method in class com.hazelcast.config.SerializationConfig
 
getServerRegistrationId() - Method in class com.hazelcast.client.impl.spi.impl.listener.ClientEventRegistration
Alias registration ID is same as registration ID in the beginning.
getServerSocketCardinality() - Method in enum com.hazelcast.instance.ProtocolType
 
getServerSocketChannel(EndpointQualifier) - Method in interface com.hazelcast.instance.AddressPicker
Returns a server channel.
getServerSocketChannels() - Method in interface com.hazelcast.instance.AddressPicker
Returns all ServerSocketChannels of this member, mapped by corresponding EndpointQualifier
getService() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
getService(String) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
getService() - Method in class com.hazelcast.cp.internal.RaftOp
 
getService() - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getService() - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
Gets the Service of this AbstractDistributedObject.
getService(String) - Method in interface com.hazelcast.spi.impl.NodeEngine
Gets the service with the given name.
getService(String) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getService() - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
getService(String) - Method in class com.hazelcast.spi.impl.servicemanager.impl.ServiceManagerImpl
 
getService(NodeEngine) - Method in interface com.hazelcast.spi.impl.servicemanager.ServiceDescriptor
 
getService() - Method in class com.hazelcast.spi.impl.servicemanager.ServiceInfo
 
getService(String) - Method in interface com.hazelcast.spi.impl.servicemanager.ServiceManager
Gets a Service by serviceName.
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
Deprecated.
getServiceInfo(String) - Method in class com.hazelcast.spi.impl.servicemanager.impl.ServiceManagerImpl
 
getServiceInfo(String) - Method in interface com.hazelcast.spi.impl.servicemanager.ServiceManager
Gets the ServiceInfo for a service by serviceName.
getServiceInfos(Class) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getServiceInfos(Class) - Method in class com.hazelcast.spi.impl.servicemanager.impl.ServiceManagerImpl
Returns a list of services matching provided service class/interface.
getServiceInfos(Class) - Method in interface com.hazelcast.spi.impl.servicemanager.ServiceManager
Gets all the service info's for services that implement a given class/interface.
getServiceManager() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getServiceName() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalReadOperation
 
getServiceName() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalSubscribeOperation
 
getServiceName() - Method in class com.hazelcast.cache.impl.operation.AddCacheConfigOperation
 
getServiceName() - Method in class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
 
getServiceName() - Method in class com.hazelcast.cache.impl.operation.CacheClearExpiredOperation
 
getServiceName() - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
Deprecated.
 
getServiceName() - Method in class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
 
getServiceName() - Method in class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation
 
getServiceName() - Method in class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
 
getServiceName() - Method in class com.hazelcast.cache.impl.operation.CacheOperation
 
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.OnJoinCacheOperation
 
getServiceName() - Method in class com.hazelcast.cache.impl.tenantcontrol.CacheDestroyEventContext
 
getServiceName() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorProxy
 
getServiceName() - Method in class com.hazelcast.cardinality.impl.operations.AbstractCardinalityEstimatorOperation
 
getServiceName() - Method in class com.hazelcast.cardinality.impl.operations.ReplicationOperation
 
getServiceName() - Method in class com.hazelcast.client.impl.client.DistributedObjectInfo
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.AddBackupListenerMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionListenerMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
 
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.CacheAddNearCacheInvalidationListenerTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsOperation
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheContainsKeyMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheCreateConfigMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalReadTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalSubscribeTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheFetchNearCacheInvalidationMetadataTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetConfigMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.Pre38CacheAddInvalidationListenerTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorAddMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorEstimateMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.ClientStatisticsMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterAddMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetConfiguredReplicaCountMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxiesMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.DeployClassesMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AbstractAddConfigMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorDisposeResultMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorIsShutdownMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveAndDisposeResultMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveResultMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorShutdownMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorSubmitToPartitionMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnAddressMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnPartitionMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.IsFailoverSupportedMessageTask
 
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.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.AbstractMapSetMessageTask
 
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.MapAddListenerMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsOperation
 
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.MapDestroyCacheMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEventJournalReadTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEventJournalSubscribeTask
 
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.MapFetchEntriesMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchKeysMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchNearCacheInvalidationMetadataTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchWithQueryMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetEntryViewMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapMadePublishableMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateWithValueMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveAllMessageTask
 
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.MapSetReadCursorMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetTtlMessageTask
 
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.metrics.ReadMetricsMessageTask
 
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.MultiMapDeleteMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapGetMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapPutMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValueCountMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddAllMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueClearMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRemoveAllMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRetainAllMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsAllMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMaxSizeMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIsEmptyMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIteratorMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueOfferMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePeekMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePollMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePutMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemainingCapacityMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueSizeMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueTakeMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddAllMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferCapacityMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferHeadSequenceMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadManyMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadOneMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferRemainingCapacityMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferSizeMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferTailSequenceMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorGetAllScheduledMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorShutdownMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToAddressMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToPartitionMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromAddressMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromPartitionMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromAddressMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromPartitionMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromAddressMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromPartitionMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromAddressMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromPartitionMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromAddressMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromPartitionMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromAddressMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromPartitionMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromAddressMessageTask
 
getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromPartitionMessageTask
 
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.impl.proxy.txn.ClientTxnListProxy
 
getServiceName() - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
getServiceName() - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMultiMapProxy
 
getServiceName() - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnQueueProxy
 
getServiceName() - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnSetProxy
 
getServiceName() - Method in class com.hazelcast.client.impl.spi.ClientProxy
 
getServiceName() - Method in interface com.hazelcast.client.impl.spi.ClientProxyDescriptor
 
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.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.TransactionalListProxy
 
getServiceName() - Method in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxySupport
 
getServiceName() - Method in class com.hazelcast.collection.impl.txnset.TransactionalSetProxy
 
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.cp.internal.datastructures.atomiclong.client.AddAndGetMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.AlterMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.ApplyMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.CompareAndSetMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetAndAddMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetAndSetMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.AbstractAtomicLongOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.ApplyMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.CompareAndSetMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.ContainsMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.GetMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.SetMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.AbstractAtomicRefOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.AwaitMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.CountDownMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.GetCountMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.GetRoundMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.TrySetCountMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.AbstractCountDownLatchOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.proxy.CountDownLatchProxy
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.GetLockOwnershipStateMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.LockMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.TryLockMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.UnlockMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.GetLockOwnershipStateOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.AcquirePermitsMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.AvailablePermitsMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.ChangePermitsMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.DrainPermitsMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.GetSemaphoreTypeMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.InitSemaphoreMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.ReleasePermitsMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.AvailablePermitsOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.ChangePermitsOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.InitSemaphoreOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionAwareSemaphoreProxy
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionlessSemaphoreProxy
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.operation.ExpireWaitKeysOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.spi.client.CreateRaftGroupMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.spi.client.DestroyRaftObjectMessageTask
 
getServiceName() - Method in class com.hazelcast.cp.internal.datastructures.spi.operation.DestroyRaftObjectOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.operation.GetLeadedGroupsOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.operation.integration.AsyncRaftOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.operation.RaftQueryOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.operation.RaftReplicateOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.operation.RestartCPMemberOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.operation.TransferLeadershipOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.operation.unsafe.AbstractUnsafeRaftOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.operation.unsafe.UnsafeStateReplicationOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.raftop.GetInitialRaftGroupMembersIfCurrentGroupMemberOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.RaftOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.raftop.metadata.CreateRaftNodeOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.raftop.metadata.DestroyRaftNodesOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.raftop.metadata.MetadataRaftGroupOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.raftop.metadata.PublishActiveCPMembersOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.raftop.metadata.RaftServicePreJoinOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.raftop.NotifyTermChangeOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.raftop.snapshot.RestoreSnapshotOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.session.operation.CloseInactiveSessionsOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.session.operation.CloseSessionOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.session.operation.CreateSessionOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.session.operation.ExpireSessionsOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.session.operation.GenerateThreadIdOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.session.operation.GetSessionsOp
 
getServiceName() - Method in class com.hazelcast.cp.internal.session.operation.HeartbeatSessionOp
 
getServiceName() - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
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.flakeidgen.impl.client.NewIdBatchMessageTask
 
getServiceName() - Method in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorProxy
 
getServiceName() - Method in class com.hazelcast.internal.cluster.impl.operations.CommitClusterStateOp
 
getServiceName() - Method in class com.hazelcast.internal.cluster.impl.operations.LockClusterStateOp
 
getServiceName() - Method in class com.hazelcast.internal.cluster.impl.operations.RollbackClusterStateOp
 
getServiceName() - Method in class com.hazelcast.internal.crdt.pncounter.operations.AbstractPNCounterOperation
 
getServiceName() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterProxy
 
getServiceName() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterReplicationOperation
 
getServiceName() - Method in class com.hazelcast.internal.dynamicconfig.AbstractDynamicConfigOperation
 
getServiceName() - Method in class com.hazelcast.internal.journal.EventJournalReadOperation
 
getServiceName() - Method in class com.hazelcast.internal.locksupport.LockWaitNotifyKey
 
getServiceName() - Method in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
getServiceName() - Method in class com.hazelcast.internal.locksupport.operations.LockReplicationOperation
 
getServiceName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterAddAndGetMessageTask
 
getServiceName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterDecrementAndGetMessageTask
 
getServiceName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndAddMessageTask
 
getServiceName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndIncrementMessageTask
 
getServiceName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndSetMessageTask
 
getServiceName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetMessageTask
 
getServiceName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterIncrementAndGetMessageTask
 
getServiceName() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterSetMessageTask
 
getServiceName() - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
getServiceName() - Method in class com.hazelcast.internal.longregister.operations.AbstractLongRegisterOperation
 
getServiceName() - Method in class com.hazelcast.internal.longregister.operations.LongRegisterReplicationOperation
 
getServiceName() - Method in class com.hazelcast.internal.metrics.managementcenter.ReadMetricsOperation
 
getServiceName() - Method in class com.hazelcast.internal.partition.NonFragmentedServiceNamespace
 
getServiceName() - Method in class com.hazelcast.internal.partition.operation.FetchPartitionStateOperation
 
getServiceName() - Method in class com.hazelcast.internal.partition.operation.HasOngoingMigration
 
getServiceName() - Method in class com.hazelcast.internal.partition.operation.MigrationCommitOperation
 
getServiceName() - Method in class com.hazelcast.internal.partition.operation.PartitionBackupReplicaAntiEntropyOperation
 
getServiceName() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRequest
 
getServiceName() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncResponse
 
getServiceName() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRetryResponse
 
getServiceName() - Method in class com.hazelcast.internal.partition.operation.PartitionStateOperation
 
getServiceName() - Method in class com.hazelcast.internal.partition.operation.PartitionStateVersionCheckOperation
 
getServiceName() - Method in class com.hazelcast.internal.partition.operation.PromotionCommitOperation
 
getServiceName() - Method in class com.hazelcast.internal.partition.operation.PublishCompletedMigrationsOperation
 
getServiceName() - Method in class com.hazelcast.internal.partition.operation.ShutdownRequestOperation
 
getServiceName() - Method in class com.hazelcast.internal.partition.operation.ShutdownResponseOperation
 
getServiceName() - Method in class com.hazelcast.internal.services.DistributedObjectNamespace
 
getServiceName() - Method in interface com.hazelcast.internal.services.ServiceNamespace
Name of the service
getServiceName() - Method in class com.hazelcast.internal.usercodedeployment.impl.operation.ClassDataFinderOperation
 
getServiceName() - Method in class com.hazelcast.internal.usercodedeployment.impl.operation.DeployClassesOperation
 
getServiceName() - Method in class com.hazelcast.map.impl.journal.MapEventJournalReadOperation
 
getServiceName() - Method in class com.hazelcast.map.impl.operation.AddIndexBackupOperation
 
getServiceName() - Method in class com.hazelcast.map.impl.operation.AddIndexOperation
 
getServiceName() - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperation
 
getServiceName() - Method in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
 
getServiceName() - Method in class com.hazelcast.map.impl.operation.MapClearExpiredOperation
 
getServiceName() - Method in class com.hazelcast.map.impl.operation.MapGetInvalidationMetaDataOperation
 
getServiceName() - Method in class com.hazelcast.map.impl.operation.MapOperation
 
getServiceName() - Method in class com.hazelcast.map.impl.operation.MapReplicationOperation
 
getServiceName() - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
 
getServiceName() - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
 
getServiceName() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
 
getServiceName() - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
 
getServiceName() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
 
getServiceName() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
getServiceName() - Method in class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
 
getServiceName() - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
 
getServiceName() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperation
 
getServiceName() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicationOperation
 
getServiceName() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
getServiceName() - Method in class com.hazelcast.ringbuffer.impl.operations.AbstractRingBufferOperation
 
getServiceName() - Method in class com.hazelcast.ringbuffer.impl.operations.MergeOperation
 
getServiceName() - Method in class com.hazelcast.ringbuffer.impl.operations.ReplicationOperation
 
getServiceName() - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
 
getServiceName() - Method in class com.hazelcast.ringbuffer.impl.RingbufferWaitNotifyKey
 
getServiceName() - Method in class com.hazelcast.scheduledexecutor.impl.operations.AbstractSchedulerOperation
 
getServiceName() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
getServiceName() - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
getServiceName() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventEnvelope
 
getServiceName() - Method in class com.hazelcast.spi.impl.eventservice.impl.LocalEventDispatcher
 
getServiceName() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
 
getServiceName() - Method in class com.hazelcast.spi.impl.operationservice.AbstractWaitNotifyKey
 
getServiceName() - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Gets the name of the service.
getServiceName() - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
getServiceName() - Method in interface com.hazelcast.spi.impl.operationservice.WaitNotifyKey
Returns the service name of the wait notify object for this key.
getServiceName() - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
 
getServiceName() - Method in class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectEventPacket
 
getServiceName() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.InitializeDistributedObjectOperation
 
getServiceName() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.PostJoinProxyOperation
 
getServiceName() - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyInfo
 
getServiceName() - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyRegistry
Returns the name of the service for this ProxyRegistry.
getServiceName() - Method in interface com.hazelcast.spi.impl.servicemanager.ServiceDescriptor
 
getServiceName() - Method in interface com.hazelcast.spi.tenantcontrol.DestroyEventContext
 
getServiceName() - Method in class com.hazelcast.topic.impl.PublishOperation
 
getServiceName() - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicProxy
 
getServiceName() - Method in class com.hazelcast.topic.impl.TopicProxySupport
 
getServiceName() - Method in class com.hazelcast.transaction.impl.operations.AbstractTxOperation
 
getServiceName() - Method in class com.hazelcast.transaction.impl.xa.operations.AbstractXAOperation
 
getServiceName() - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
 
getServiceName() - Method in interface com.hazelcast.wan.WanReplicationEvent
Returns the service name on which this event occurred.
getServiceNamespace() - Method in class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
 
getServiceNamespace() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
 
getServiceNamespace() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
 
getServiceNamespace() - Method in class com.hazelcast.cache.impl.operation.CacheOperation
 
getServiceNamespace() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
 
getServiceNamespace() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
 
getServiceNamespace() - Method in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
getServiceNamespace(Operation) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
 
getServiceNamespace(Operation) - Method in interface com.hazelcast.internal.partition.PartitionReplicaVersionManager
Returns ServiceNamespace for given operation.
getServiceNamespace() - Method in interface com.hazelcast.internal.services.ServiceNamespaceAware
Returns the ServiceNamespace which this object belongs to.
getServiceNamespace() - Method in class com.hazelcast.map.impl.operation.MapOperation
 
getServiceNamespace() - Method in class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
 
getServiceNamespace() - Method in class com.hazelcast.ringbuffer.impl.operations.AbstractRingBufferOperation
 
getServiceNamespace() - Method in class com.hazelcast.ringbuffer.impl.operations.MergeOperation
 
getServiceOrNull(String) - Method in interface com.hazelcast.spi.impl.NodeEngine
Gets the service for the given serviceName if it exists or null otherwise.
getServiceOrNull(String) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getServices(Class<S>) - Method in interface com.hazelcast.spi.impl.NodeEngine
Returns a list of services matching provides service class/interface.
getServices(Class<S>) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getServices(Class<S>) - Method in class com.hazelcast.spi.impl.servicemanager.impl.ServiceManagerImpl
 
getServices(Class<S>) - Method in interface com.hazelcast.spi.impl.servicemanager.ServiceManager
Gets all services implementing a certain class/interface.
getServicesConfig() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getServicesConfig() - Method in class com.hazelcast.config.Config
Returns the configuration for the user services managed by this hazelcast instance.
getServicesConfig() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getSession(RaftGroupId) - Method in class com.hazelcast.cp.internal.session.AbstractProxySessionManager
Returns id of the session opened for the given Raft group.
getSession() - Method in class com.hazelcast.cp.internal.session.SessionAwareProxy
Returns id of the session opened for the given Raft group.
getSessionAcquireCount(RaftGroupId, long) - Method in class com.hazelcast.cp.internal.session.AbstractProxySessionManager
 
getSessionHeartbeatIntervalSeconds() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the interval for the periodically-committed CP session heartbeats.
getSessionId() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockOwnershipState
Returns the session id that currently holds the lock.
getSessionId() - Method in class com.hazelcast.cp.internal.session.SessionResponse
 
getSessionsLocally(CPGroupId) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
GetSessionsOp - Class in com.hazelcast.cp.internal.session.operation
Returns the collection of active sessions in the given Raft group
GetSessionsOp() - Constructor for class com.hazelcast.cp.internal.session.operation.GetSessionsOp
 
getSessionTimeToLiveSeconds() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the duration for a CP session to be kept alive after its last session heartbeat.
getSet() - Method in class com.hazelcast.client.console.ClientConsoleApp
 
getSet(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getSet(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getSet(String) - Method in class com.hazelcast.client.impl.proxy.txn.TransactionContextProxy
 
getSet(String) - Method in class com.hazelcast.client.impl.proxy.txn.xa.XATransactionContextProxy
 
getSet() - Method in class com.hazelcast.console.ConsoleApp
 
getSet(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed set instance with the specified name.
getSet(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getSet(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getSet(String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
 
getSet(String) - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
 
getSet(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
Returns the transactional set instance with the specified name.
getSetConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getSetConfig(String) - Method in class com.hazelcast.config.Config
Returns the SetConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getSetConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getSetConfigs() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getSetConfigs() - Method in class com.hazelcast.config.Config
Returns the map of ISet configurations, mapped by config name.
getSetConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
getSetConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Returns all registered set configurations.
getSetConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getSetOperationCount() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
getSetOperationCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
getSetOperationCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
getSetOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of set operations
getShort(Object, long) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Returns the short value at the supplied offset from the supplied object's base address.
getShort(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getShort(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getShort(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getShort(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getShort(long) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Reads the short value from given address.
getShortVolatile(Object, long) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Reads the short value as volatile from given object by its offset.
getShortVolatile(long) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Reads the short value as volatile from given object by its offset.
getShortVolatile(long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getShortVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
getShortVolatile(long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getShortVolatile(Object, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
getSingleType() - Method in enum com.hazelcast.nio.serialization.FieldType
 
getSize() - Method in class com.hazelcast.client.impl.protocol.ClientMessage.Frame
 
getSize() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.EvictionConfigHolder
 
getSize() - Method in interface com.hazelcast.client.impl.spi.ClientClusterService
Gets the current number of members.
getSize(MemberSelector) - Method in interface com.hazelcast.client.impl.spi.ClientClusterService
Gets the number of members that satisfy the given MemberSelector instance.
getSize() - Method in class com.hazelcast.client.impl.spi.impl.ClientClusterServiceImpl
 
getSize(MemberSelector) - Method in class com.hazelcast.client.impl.spi.impl.ClientClusterServiceImpl
 
getSize() - Method in class com.hazelcast.config.EvictionConfig
Returns the size which is used by the EvictionConfig.MaxSizePolicy.
getSize() - Method in class com.hazelcast.config.MaxSizeConfig
Returns the size of the map.
getSize() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns size of the native memory region.
getSize() - Method in interface com.hazelcast.internal.cluster.ClusterService
Gets the current number of members.
getSize(MemberSelector) - Method in interface com.hazelcast.internal.cluster.ClusterService
Gets the number of members that satisfy the given MemberSelector instance.
getSize() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getSize(MemberSelector) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getSize() - Method in class com.hazelcast.internal.jmx.MapMBean
 
getSize() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
getSize() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
getSlowOperationDTOs() - Method in class com.hazelcast.spi.impl.operationexecutor.slowoperationdetector.SlowOperationDetector
 
getSlowOperationDTOs() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
getSlowOperationDTOs() - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Returns information about long running operations.
getSlowOperations() - Method in class com.hazelcast.monitor.impl.LocalOperationStatsImpl
 
getSnapshot() - Method in class com.hazelcast.cp.internal.raftop.snapshot.RestoreSnapshotOp
 
getSnapshotMap(int) - Method in class com.hazelcast.cp.internal.datastructures.spi.AbstractCPMigrationAwareService
 
getSnapshotMap(int) - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueService
 
getSnapshotMap(int) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
getSnapshotMap(int) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
getSocketAddress() - Method in interface com.hazelcast.client.Client
Returns the socket address of this client.
getSocketAddress() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
getSocketAddress() - Method in class com.hazelcast.client.impl.ClientEvent
 
getSocketAddress() - Method in class com.hazelcast.client.impl.ClientImpl
 
getSocketAddress() - Method in interface com.hazelcast.cluster.Endpoint
Returns the socket address for this endpoint.
getSocketAddress() - Method in class com.hazelcast.cluster.impl.AbstractMember
 
getSocketAddress(EndpointQualifier) - Method in class com.hazelcast.cluster.impl.AbstractMember
 
getSocketAddress() - Method in interface com.hazelcast.cluster.Member
Returns the socket address of this member for member to member communications or unified depending on config.
getSocketAddress(EndpointQualifier) - Method in interface com.hazelcast.cluster.Member
Returns the socket address of this member.
getSocketAddresses(String) - Static method in class com.hazelcast.client.util.AddressHelper
 
getSocketConnectTimeoutSeconds() - Method in class com.hazelcast.config.EndpointConfig
 
getSocketConnectTimeoutSeconds(EndpointQualifier) - Method in interface com.hazelcast.internal.nio.IOService
 
getSocketConnectTimeoutSeconds(EndpointQualifier) - Method in class com.hazelcast.internal.nio.NodeIOService
 
getSocketFactoryClassName() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getSocketInterceptor() - Method in class com.hazelcast.client.impl.clientside.CandidateClusterContext
 
getSocketInterceptor(EndpointQualifier) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
getSocketInterceptor(EndpointQualifier) - Method in interface com.hazelcast.instance.impl.NodeExtension
Returns MemberSocketInterceptor for this Node if available, otherwise returns null.
getSocketInterceptor(EndpointQualifier) - Method in interface com.hazelcast.internal.nio.IOService
 
getSocketInterceptor(EndpointQualifier) - Method in class com.hazelcast.internal.nio.NodeIOService
 
getSocketInterceptorConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
getSocketInterceptorConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getSocketInterceptorConfig() - Method in class com.hazelcast.config.EndpointConfig
getSocketInterceptorConfig() - Method in class com.hazelcast.config.NetworkConfig
getSocketInterceptorConfig(EndpointQualifier) - Method in class com.hazelcast.internal.nio.NodeIOService
 
getSocketLingerSeconds() - Method in class com.hazelcast.config.EndpointConfig
 
getSocketOptions() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
getSocketRcvBufferSizeKb() - Method in class com.hazelcast.config.EndpointConfig
 
getSocketSendBufferSizeKb() - Method in class com.hazelcast.config.EndpointConfig
 
getSortedQueryResultSet(List<Map.Entry>, PagingPredicate, IterationType) - Static method in class com.hazelcast.internal.util.SortingUtil
 
getSortedSubList(List<QueryableEntry>, PagingPredicate, Map.Entry<Integer, Map.Entry>) - Static method in class com.hazelcast.internal.util.SortingUtil
 
getSource() - Method in class com.hazelcast.cache.impl.event.AbstractICacheEvent
Returns the object on which the event initially occurred.
getSource() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
getSource() - Method in class com.hazelcast.internal.partition.ReplicaMigrationEventImpl
 
getSource() - Method in class com.hazelcast.map.AbstractIMapEvent
Returns the object on which the event initially occurred.
getSource() - Method in interface com.hazelcast.map.impl.event.EventData
 
getSource() - Method in class com.hazelcast.map.impl.mapstore.writebehind.StoreEvent
 
getSource() - Method in class com.hazelcast.map.impl.querycache.event.BatchEventData
 
getSource() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
getSource() - Method in class com.hazelcast.map.impl.querycache.event.LocalCacheWideEventData
 
getSource() - Method in class com.hazelcast.map.impl.querycache.event.LocalEntryEventData
 
getSource() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
Returns the old owner of the migrating partition replica.
getSource() - Method in class com.hazelcast.spi.impl.PortablePartitionLostEvent
 
getSourceAddress() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
getSourceCurrentReplicaIndex() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
getSourceNewReplicaIndex() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
getSourceUuid() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidation
 
getSpecificationName() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
 
getSpecificationVendor() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
 
getSpecificationVersion() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
 
getSplitBrainMergePolicyProvider() - Method in interface com.hazelcast.spi.impl.NodeEngine
Returns the SplitBrainMergePolicyProvider for this instance.
getSplitBrainMergePolicyProvider() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getSplitBrainMessagesCount() - Method in class com.hazelcast.internal.cluster.impl.MulticastJoiner
 
getSplitBrainProtection(String) - Method in class com.hazelcast.splitbrainprotection.impl.SplitBrainProtectionServiceImpl
 
getSplitBrainProtection(String) - Method in interface com.hazelcast.splitbrainprotection.SplitBrainProtectionService
Returns the SplitBrainProtection instance for a given split brain protection name.
getSplitBrainProtectionConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getSplitBrainProtectionConfig(String) - Method in class com.hazelcast.config.Config
Returns the SplitBrainProtectionConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getSplitBrainProtectionConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getSplitBrainProtectionConfigs() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getSplitBrainProtectionConfigs() - Method in class com.hazelcast.config.Config
Returns the map of split brain protection configurations, mapped by config name.
getSplitBrainProtectionConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getSplitBrainProtectionName(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
Gets the name of the split brain protection associated with specified cache
getSplitBrainProtectionName(String) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorService
 
getSplitBrainProtectionName() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
getSplitBrainProtectionName(String) - Method in class com.hazelcast.collection.impl.list.ListService
 
getSplitBrainProtectionName(String) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
getSplitBrainProtectionName(String) - Method in class com.hazelcast.collection.impl.set.SetService
 
getSplitBrainProtectionName() - Method in class com.hazelcast.config.AbstractBasicConfig
Returns the split brain protection name for operations.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.CacheConfig
Gets the name of the associated split brain protection if any.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the name of the associated split brain protection if any.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Returns the split brain protection name for operations.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.CollectionConfig
Returns the split brain protection name for operations.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.DurableExecutorConfig
Returns the split brain protection name for operations.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.ExecutorConfig
Returns the split brain protection name for operations.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.MapConfig
 
getSplitBrainProtectionName() - Method in class com.hazelcast.config.MultiMapConfig
Returns the split brain protection name for operations.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.PNCounterConfig
Returns the split brain protection name for operations.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.QueueConfig
Returns the split brain protection name for queue operations.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.ReplicatedMapConfig
Returns the split brain protection name for operations.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.RingbufferConfig
Returns the split brain protection name for operations.
getSplitBrainProtectionName() - Method in class com.hazelcast.config.ScheduledExecutorConfig
Returns the split brain protection name for operations.
getSplitBrainProtectionName(String) - Method in class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
 
getSplitBrainProtectionName(String) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
 
getSplitBrainProtectionName() - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
getSplitBrainProtectionName(String) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterService
 
getSplitBrainProtectionName(String) - Method in interface com.hazelcast.internal.services.SplitBrainProtectionAwareService
Gets the name of the split brain protection associated with specified operation name.
getSplitBrainProtectionName() - Method in class com.hazelcast.map.impl.MapContainer
 
getSplitBrainProtectionName(String) - Method in class com.hazelcast.map.impl.MapService
 
getSplitBrainProtectionName(String) - Method in class com.hazelcast.map.impl.MapSplitBrainProtectionAwareService
 
getSplitBrainProtectionName(String) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
getSplitBrainProtectionName(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
getSplitBrainProtectionName(String) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
getSplitBrainProtectionName(String) - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
getSplitBrainProtectionService() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getSplitBrainProtectionService() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getSplitBrainProtectionService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the split brain protection service of this Hazelcast instance.
getSplitBrainProtectionService() - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getSplitBrainProtectionService() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getSplitBrainProtectionService() - Method in interface com.hazelcast.spi.impl.NodeEngine
Gets the SplitBrainProtectionService.
getSplitBrainProtectionService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getSql() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.PredicateConfigHolder
 
getSql() - Method in class com.hazelcast.config.PredicateConfig
Returns sql string for this config.
getSSLConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the current SSLConfig.
getSSLConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getSSLConfig() - Method in class com.hazelcast.config.EndpointConfig
Returns the current SSLConfig.
getSSLConfig() - Method in class com.hazelcast.config.NetworkConfig
Returns the current SSLConfig.
getSSLConfig() - Method in class com.hazelcast.config.VaultSecureStoreConfig
Returns the SSL/TLS configuration.
getSSLConfig(EndpointQualifier) - Method in interface com.hazelcast.internal.nio.IOService
 
getSSLConfig(EndpointQualifier) - Method in class com.hazelcast.internal.nio.NodeIOService
 
getSSLContext() - Method in class com.hazelcast.nio.ssl.BasicSSLContextFactory
 
getSSLContext() - Method in interface com.hazelcast.nio.ssl.SSLContextFactory
 
getStackTraceElements() - Method in class com.hazelcast.client.impl.protocol.exception.ErrorHolder
 
getStaleReadDetector() - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
getStaleSequence() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataContainer
 
getStartedTaskCount() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
 
getStartedTaskCount() - Method in interface com.hazelcast.monitor.LocalExecutorStats
Returns the number of started operations on the executor service.
getStartFrame() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
getStartTime() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
getStartTime() - Method in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
getStartTime() - Method in interface com.hazelcast.internal.cluster.Joiner
 
getStartTime() - Method in class com.hazelcast.internal.partition.MigrationStateImpl
 
getStartTime() - Method in interface com.hazelcast.partition.MigrationState
Returns the start time of the migration in milliseconds since the epoch.
getStartTime() - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
getStartTime() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
 
getStartTime() - Method in class com.hazelcast.transaction.impl.xa.XATransactionDTO
 
getState() - Method in class com.hazelcast.client.impl.proxy.txn.xa.XATransactionProxy
 
getState() - Method in class com.hazelcast.core.LifecycleEvent
 
getState() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
getState() - Method in class com.hazelcast.instance.impl.Node
Returns the node state.
getState() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateManager
 
getState() - Method in class com.hazelcast.internal.jmx.WanPublisherMBean
 
getState() - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
getState() - Method in class com.hazelcast.transaction.impl.SuspendedTransaction
 
getState() - Method in interface com.hazelcast.transaction.impl.Transaction
 
getState() - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
getState() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
 
getStaticConfig(Config, String) - Method in interface com.hazelcast.internal.dynamicconfig.search.ConfigSupplier
Get static configuration for the given name
getStaticConfigs(Config) - Method in interface com.hazelcast.internal.dynamicconfig.search.ConfigSupplier
Get all static configs for the given config type.
getStatistics(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
getStatistics(String) - Method in interface com.hazelcast.cache.impl.ICacheService
 
getStatistics(String) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
GetStatisticsOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
GetStatisticsOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetStatisticsOperation
 
GetStatisticsOperation(ScheduledTaskHandler) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.GetStatisticsOperation
 
getStats() - Method in class com.hazelcast.client.impl.proxy.ClientScheduledFutureProxy
 
getStats() - Method in class com.hazelcast.collection.impl.queue.QueueService
 
getStats() - Method in class com.hazelcast.executor.impl.DistributedExecutorService
 
getStats() - Method in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorService
 
getStats() - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
getStats() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
getStats() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterService
 
getStats() - Method in class com.hazelcast.internal.partition.impl.MigrationManager
 
getStats() - Method in interface com.hazelcast.internal.services.StatisticsAwareService
Return the service statistics for the local instance.
getStats() - Method in class com.hazelcast.map.impl.MapService
 
getStats() - Method in class com.hazelcast.multimap.impl.MultiMapService
 
getStats() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
getStats() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
getStats() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledFutureProxy
 
getStats() - Method in interface com.hazelcast.scheduledexecutor.IScheduledFuture
Returns the statistics and time measurement info of the execution of this scheduled future in the IScheduledExecutorService it was scheduled.
getStats() - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicService
 
getStats() - Method in class com.hazelcast.topic.impl.TopicService
 
getStats() - Method in class com.hazelcast.wan.impl.DelegatingWanReplicationScheme
 
getStats() - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
 
getStats() - Method in interface com.hazelcast.wan.WanReplicationPublisher
Gathers statistics of related WanReplicationPublisher instance.
getStatsMap() - Method in class com.hazelcast.topic.impl.TopicService
 
getStatus() - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Returns the current status of this node.
getStatus() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
getStatus() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
getStatus() - Method in class com.hazelcast.monitor.impl.WanSyncStateImpl
 
getStatus() - Method in interface com.hazelcast.monitor.WanSyncState
 
getStatus() - Method in enum com.hazelcast.wan.impl.WanSyncStatus
 
getStorage() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
getStorage() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
getStorage() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
getStorageRef() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
getStore() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
 
getStore() - Method in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
 
getStore() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
 
getStoreAdapter() - Method in class com.hazelcast.query.impl.QueryableEntry
 
getStoreImplementation() - Method in class com.hazelcast.config.QueueStoreConfig
 
getStoreImplementation() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
getStoreInitialDelaySeconds() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
getStoreIntervalSeconds() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
getStores() - Method in class com.hazelcast.replicatedmap.impl.PartitionContainer
 
getStoreTime() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntry
 
getString(String, String) - Method in class com.hazelcast.internal.json.JsonObject
Returns the String value of the member with the specified name in this object.
getString(JsonObject, String) - Static method in class com.hazelcast.internal.util.JsonUtil
Returns a field in a Json object as a string.
getString(JsonObject, String, String) - Static method in class com.hazelcast.internal.util.JsonUtil
Returns a field in a Json object as a string.
getString(HazelcastProperty) - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns the configured value of a HazelcastProperty as String.
getSubject() - Method in interface com.hazelcast.client.impl.ClientEndpoint
 
getSubject() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
getSubscriber() - Method in class com.hazelcast.client.impl.spi.impl.listener.ClientEventRegistration
This is used when removing the listener.
getSubscriber() - Method in interface com.hazelcast.spi.impl.eventservice.EventRegistration
Returns the subscriber of this registration.
getSubscriber() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
 
getSubscriberContext() - Method in class com.hazelcast.client.impl.querycache.ClientQueryCacheContext
 
getSubscriberContext() - Method in class com.hazelcast.map.impl.querycache.NodeQueryCacheContext
 
getSubscriberContext() - Method in interface com.hazelcast.map.impl.querycache.QueryCacheContext
Returns SubscriberContext for this context.
getSubscriberContextSupport() - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientSubscriberContext
 
getSubscriberContextSupport() - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeSubscriberContext
 
getSubscriberContextSupport() - Method in interface com.hazelcast.map.impl.querycache.subscriber.SubscriberContext
Returns SubscriberContextSupport for this context.
getSupportedWanProtocolVersions() - Method in interface com.hazelcast.wan.impl.WanReplicationService
Returns an immutable collection of all WAN protocol versions supported by this instance.
getSupportedWanProtocolVersions() - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
 
getSuspicionThreshold() - Method in class com.hazelcast.splitbrainprotection.impl.ProbabilisticSplitBrainProtectionFunction
 
getSymmetricEncryptionConfig() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
getSymmetricEncryptionConfig() - Method in class com.hazelcast.config.EndpointConfig
getSymmetricEncryptionConfig() - Method in class com.hazelcast.config.NetworkConfig
getSymmetricEncryptionConfig(EndpointQualifier) - Method in interface com.hazelcast.internal.nio.IOService
 
getSymmetricEncryptionConfig(EndpointQualifier) - Method in class com.hazelcast.internal.nio.NodeIOService
 
getSyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
 
getSyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
 
getSyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheOperation
 
getSyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
 
getSyncBackupCount() - Method in class com.hazelcast.cardinality.impl.operations.CardinalityEstimatorBackupAwareOperation
 
getSyncBackupCount() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionBackupAwareOperation
 
getSyncBackupCount() - Method in class com.hazelcast.collection.impl.queue.operations.QueueBackupAwareOperation
 
getSyncBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
Deprecated.
getSyncBackupCount() - Method in class com.hazelcast.cp.internal.operation.unsafe.UnsafeRaftReplicateOp
 
getSyncBackupCount() - Method in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
getSyncBackupCount() - Method in class com.hazelcast.internal.longregister.operations.LongRegisterBackupAwareOperation
 
getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.AddIndexOperation
 
getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.BasePutOperation
 
getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
 
getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.ClearOperation
 
getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
 
getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EntryOperation
 
getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
 
getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EvictOperation
 
getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.MapFlushOperation
 
getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.MergeOperation
 
getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
 
getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
 
getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
 
getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
 
getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.SetTtlOperation
 
getSyncBackupCount() - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
 
getSyncBackupCount() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
 
getSyncBackupCount() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
 
getSyncBackupCount() - Method in class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
 
getSyncBackupCount() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
 
getSyncBackupCount() - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
 
getSyncBackupCount() - Method in class com.hazelcast.ringbuffer.impl.operations.MergeOperation
 
getSyncBackupCount() - Method in class com.hazelcast.scheduledexecutor.impl.operations.AbstractBackupAwareSchedulerOperation
 
getSyncBackupCount() - Method in interface com.hazelcast.spi.impl.operationservice.BackupAwareOperation
The synchronous backup count.
getSyncBackupCount() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
 
getSyncBackupCount() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
 
getSyncBackupCount() - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionOperation
 
getSyncCount() - Method in class com.hazelcast.wan.DistributedServiceWanEventCounters.DistributedObjectWanEventCounters
Returns the number of entry sync events
getSyncedPartitionCount() - Method in class com.hazelcast.monitor.impl.WanSyncStateImpl
 
getSyncedPartitionCount() - Method in interface com.hazelcast.monitor.WanSyncState
 
getSyncInternal(Object, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
getSystemExecutorMBean() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getSystemLoadAverage() - Static method in class com.hazelcast.internal.util.OperatingSystemMXBeanSupport
Reads the system load average attribute from OperatingSystemMXBean.
getSystemProperty() - Method in class com.hazelcast.spi.properties.HazelcastProperty
Gets the system property value of the property.
getSystemUserDn() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getSystemUserPassword() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getTableIndex() - Method in class com.hazelcast.cache.impl.CacheEntryIterationResult
 
getTableIndex() - Method in class com.hazelcast.cache.impl.CacheKeyIterationResult
 
getTag() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
getTagKey() - Method in class com.hazelcast.config.AwsConfig
getTagName() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getTags() - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Returns the collection of supported tags.
getTagValue() - Method in class com.hazelcast.config.AwsConfig
getTailSequence() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Returns the sequence of the tail.
getTarget() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateTransactionLogRecord
 
getTarget() - Method in class com.hazelcast.query.impl.predicates.PartitionPredicateImpl
Returns the target Predicate.
getTarget() - Method in class com.hazelcast.query.impl.predicates.SkipIndexPredicate
 
getTarget() - Method in interface com.hazelcast.query.PartitionPredicate
Returns the target Predicate.
getTarget() - Method in exception com.hazelcast.spi.exception.WrongTargetException
 
getTarget() - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Returns the target machine.
getTarget() - Method in interface com.hazelcast.transaction.impl.TargetAwareTransactionLogRecord
Returns target of changes made by this transaction record.
getTargetAddress() - Method in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
getTargetAddress() - Method in class com.hazelcast.internal.cluster.impl.BindMessage
 
getTargetAddress() - Method in class com.hazelcast.internal.cluster.impl.ExtendedBindMessage
 
getTargetEndpoints() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the comma separated list of target cluster members, e.g.
getTargetExecutionCallback() - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
 
getTargetObject(boolean) - Method in class com.hazelcast.query.impl.CachedQueryEntry
 
getTargetObject(boolean) - Method in class com.hazelcast.query.impl.QueryableEntry
 
getTargetObject(boolean) - Method in class com.hazelcast.query.impl.QueryEntry
 
getTargets() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMultiTargetMessageTask
 
getTargets() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxiesMessageTask
 
getTargets() - Method in class com.hazelcast.client.impl.protocol.task.DeployClassesMessageTask
 
getTargets() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddInterceptorMessageTask
 
getTargets() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
 
getTargets() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XACollectTransactionsMessageTask
 
getTask() - Method in class com.hazelcast.internal.eviction.ExpirationManager
 
getTaskId() - Method in interface com.hazelcast.durableexecutor.DurableExecutorServiceFuture
A unique ID for the executing task
getTaskName() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
 
getTaskName() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Returns the name of the task.
getTaskQueues() - Method in class com.hazelcast.internal.util.executor.StripedExecutor
 
getTasks() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
getTaskScheduler(String) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
getTaskScheduler(String) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
getTcpIpConfig() - Method in class com.hazelcast.config.JoinConfig
 
getTenantControl(CacheConfig<K, V>) - Static method in class com.hazelcast.config.CacheConfigAccessor
 
GetterFactory - Class in com.hazelcast.query.impl.getters
 
getterIntoProperty(String) - Static method in class com.hazelcast.internal.util.StringUtil
Convert getter into a property name Example: 'getFoo' is converted into 'foo' It's written defensively, when output is not a getter then it returns the original name.
getTextCommandService() - Method in class com.hazelcast.instance.impl.Node
 
getTextCommandService() - Method in interface com.hazelcast.internal.nio.IOService
 
getTextCommandService() - Method in class com.hazelcast.internal.nio.NodeIOService
 
getTextContent(Node) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
getTextContent(Node, boolean) - Static method in class com.hazelcast.config.DomConfigHelper
 
getTextContent() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getTextContent(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
getThisAddress() - Method in interface com.hazelcast.client.impl.ClientEngine
 
getThisAddress() - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
getThisAddress() - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
getThisAddress() - Method in class com.hazelcast.instance.impl.Node
 
getThisAddress() - Method in interface com.hazelcast.internal.cluster.ClusterService
Gets the address of this member.
getThisAddress() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getThisAddress() - Method in interface com.hazelcast.internal.nio.IOService
 
getThisAddress() - Method in class com.hazelcast.internal.nio.NodeIOService
 
getThisAddress() - Method in interface com.hazelcast.spi.impl.NodeEngine
Get the address of this member.
getThisAddress() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getThisAddresses() - Method in interface com.hazelcast.internal.nio.IOService
 
getThisAddresses() - Method in class com.hazelcast.internal.nio.NodeIOService
 
getThisNodesAddress() - Method in class com.hazelcast.client.impl.querycache.ClientQueryCacheContext
 
getThisNodesAddress() - Method in class com.hazelcast.map.impl.event.AbstractFilteringStrategy
 
getThisNodesAddress() - Method in class com.hazelcast.map.impl.querycache.NodeQueryCacheContext
 
getThisNodesAddress() - Method in interface com.hazelcast.map.impl.querycache.QueryCacheContext
Returns this nodes address.
getThisUuid() - Method in class com.hazelcast.instance.impl.Node
 
getThisUuid() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
getThreadId() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockOwnershipState
Returns the thread id that holds the lock.
getThreadId() - Method in interface com.hazelcast.internal.locksupport.LockResource
 
getThreadId() - Static method in class com.hazelcast.internal.util.ThreadUtil
Get the thread ID.
getThreadId() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
 
getThreadId() - Method in class com.hazelcast.map.impl.operation.MapOperation
 
getThreadId() - Method in class com.hazelcast.map.impl.operation.ReadonlyKeyBasedMapOperation
 
getThreadId() - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
 
getThreadId() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationThread
 
getThreads() - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
getThreshold() - Method in class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
Returns the predefined split brain protection threshold
getTime() - Method in class com.hazelcast.internal.management.TimedMemberState
 
getTimedExpiryPolicyFactoryConfig() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
getTimeInMillis(long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
getTimeout() - Method in interface com.hazelcast.internal.util.executor.TimeoutRunnable
 
getTimeout() - Method in class com.hazelcast.spi.impl.eventservice.impl.LocalEventDispatcher
 
getTimeoutMilis() - Method in class com.hazelcast.transaction.impl.xa.XATransactionDTO
 
getTimeoutMillis() - Method in class com.hazelcast.transaction.impl.SuspendedTransaction
 
getTimeoutMillis() - Method in interface com.hazelcast.transaction.impl.Transaction
 
getTimeoutMillis() - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
getTimeoutMillis() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
 
getTimeoutMillis() - Method in class com.hazelcast.transaction.TransactionOptions
Gets the timeout in milliseconds.
getTimeoutMilliseconds() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
getTimeoutMilliseconds() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
getTimestamp() - Method in interface com.hazelcast.internal.auditlog.AuditableEvent
Returns event timestamp as milliseconds from the epoch.
getTimestamp() - Method in class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService.NoOpEvent
 
getTimestamp() - Method in class com.hazelcast.internal.management.events.AbstractEventBase
 
getTimestamp() - Method in interface com.hazelcast.internal.management.events.Event
Returns when the event happened as epoch millis.
getTimestampForReplica(UUID) - Method in class com.hazelcast.cluster.impl.VectorClock
Returns logical timestamp for given replicaId.
getTimeToLiveSeconds() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.NearCacheConfigHolder
 
getTimeToLiveSeconds() - Method in class com.hazelcast.config.EventJournalConfig
Gets the time to live in seconds.
getTimeToLiveSeconds() - Method in class com.hazelcast.config.MapConfig
Returns the maximum number of seconds for each entry to stay in the map.
getTimeToLiveSeconds() - Method in class com.hazelcast.config.NearCacheConfig
Returns the maximum number of seconds for each entry to stay in the Near Cache (time to live).
getTimeToLiveSeconds() - Method in class com.hazelcast.config.RingbufferConfig
Gets the time to live in seconds.
getTimeUnit() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
getTimeUnit() - Method in interface com.hazelcast.internal.util.executor.TimeoutRunnable
 
getTimeUnit() - Method in class com.hazelcast.spi.impl.eventservice.impl.LocalEventDispatcher
 
getTimeUnit() - Method in class com.hazelcast.spi.properties.HazelcastProperty
Returns the TimeUnit of the property.
getTlsAuthenticationConfig() - Method in class com.hazelcast.config.security.RealmConfig
 
getTo() - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
 
getTo() - Method in class com.hazelcast.query.impl.predicates.BoundedRangePredicate
 
getTo() - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
 
getTo() - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
 
getTo() - Method in interface com.hazelcast.query.impl.predicates.RangePredicate
 
getToken() - Method in class com.hazelcast.config.security.TokenIdentityConfig
 
getToken() - Method in class com.hazelcast.config.VaultSecureStoreConfig
Returns the Vault access token.
getToken() - Method in class com.hazelcast.security.SimpleTokenCredentials
Gets the token.
getToken() - Method in interface com.hazelcast.security.TokenCredentials
Returns the token as a byte array.
getTokenEncoded() - Method in class com.hazelcast.config.security.TokenIdentityConfig
 
getTokenEncoding(String) - Static method in enum com.hazelcast.config.security.TokenEncoding
 
getTokenIdentityConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
getTokenIdentityConfig() - Method in class com.hazelcast.config.security.RealmConfig
 
getTopic() - Method in class com.hazelcast.client.console.ClientConsoleApp
 
getTopic(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getTopic(String) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getTopic() - Method in class com.hazelcast.console.ConsoleApp
 
getTopic(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates or returns the distributed topic instance with the specified name.
getTopic(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getTopic(String) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getTopic() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
 
getTopicConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getTopicConfig(String) - Method in class com.hazelcast.config.Config
Returns the TopicConfig for the given name, creating one if necessary and adding it to the collection of known configurations.
getTopicConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getTopicConfigs() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getTopicConfigs() - Method in class com.hazelcast.config.Config
Returns the map of reliable topic configurations, mapped by config name.
getTopicConfigs() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
getTopicConfigs() - Method in interface com.hazelcast.internal.dynamicconfig.ConfigurationService
Returns all registered topic configurations.
getTopicConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getTopicOverloadPolicy() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Gets the TopicOverloadPolicy for this reliable topic.
getTopicOverloadPolicy() - Method in class com.hazelcast.config.ReliableTopicConfig
Gets the TopicOverloadPolicy for this reliable topic.
getTotal() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
getTotalBackupCount() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
 
getTotalBackupCount() - Method in class com.hazelcast.config.CacheConfig
Gets the total backup count (backupCount + asyncBackupCount) of the cache.
getTotalBackupCount() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Returns the total number of backups: backupCount plus asyncBackupCount.
getTotalBackupCount() - Method in class com.hazelcast.config.CollectionConfig
Gets the total number of synchronous and asynchronous backups for this collection.
getTotalBackupCount() - Method in class com.hazelcast.config.MapConfig
Returns the total number of backups: backupCount plus asyncBackupCount.
getTotalBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
Gets the total number of backups (synchronous + asynchronous) for this MultiMap.
getTotalBackupCount() - Method in class com.hazelcast.config.QueueConfig
Get the total number of backups: the backup count plus the asynchronous backup count.
getTotalBackupCount() - Method in class com.hazelcast.config.RingbufferConfig
Returns the total number of backups: backupCount plus asyncBackupCount.
getTotalBackupCount() - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
getTotalBackupCount() - Method in class com.hazelcast.map.impl.MapContainer
 
getTotalCompletedMigrations() - Method in class com.hazelcast.internal.partition.impl.MigrationStats
Returns the total number of completed migrations since the beginning.
getTotalConnections() - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
getTotalDecrementOperationCount() - Method in class com.hazelcast.monitor.impl.LocalPNCounterStatsImpl
 
getTotalDecrementOperationCount() - Method in interface com.hazelcast.monitor.LocalPNCounterStats
Returns the total number of subtract (including decrement) operations on this PN counter on this member.
getTotalElapsedDestinationCommitTime() - Method in class com.hazelcast.internal.partition.impl.MigrationStats
Returns the total elapsed time of commit operations' executions to the destination endpoint, in milliseconds, since the beginning.
getTotalElapsedMigrationOperationTime() - Method in class com.hazelcast.internal.partition.impl.MigrationStats
Returns the total elapsed time of migration & replication operations' executions from source to destination endpoints, in milliseconds, since the beginning.
getTotalElapsedMigrationTime() - Method in class com.hazelcast.internal.partition.impl.MigrationStats
Returns the total elapsed time from start of migration tasks to their completion, in milliseconds, since the beginning.
getTotalElapsedTime() - Method in class com.hazelcast.internal.partition.MigrationStateImpl
 
getTotalElapsedTime() - Method in interface com.hazelcast.partition.MigrationState
Returns the total elapsed time of completed migrations in milliseconds.
getTotalExecutionLatency() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
 
getTotalExecutionLatency() - Method in interface com.hazelcast.monitor.LocalExecutorStats
Returns the total execution time of operations finished.
getTotalGetLatency() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
getTotalGetLatency() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
getTotalGetLatency() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
getTotalGetLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total latency of get operations.
getTotalHitCount() - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Returns the total hit count.
getTotalHitLatency() - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
getTotalHitLatency() - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
getTotalHitLatency() - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Returns the total hit latency for the index.
getTotalIdleTime(TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskStatisticsImpl
 
getTotalIdleTime(TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
Returns the total amount of time the task was idle, waiting to get scheduled in.
getTotalIncrementOperationCount() - Method in class com.hazelcast.monitor.impl.LocalPNCounterStatsImpl
 
getTotalIncrementOperationCount() - Method in interface com.hazelcast.monitor.LocalPNCounterStats
Returns the total number of add (including increment) operations on this PN counter on this member.
getTotalInsertLatency() - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
getTotalInsertLatency() - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
 
getTotalInsertLatency() - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Returns the total insert latency.
getTotalInsertLatency() - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
getTotalInsertLatency() - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Returns the total latency (in nanoseconds) of insert operations performed on the index.
getTotalInsertLatency() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the total latency (in nanoseconds) of insert operations performed on the index.
getTotalMemory() - Method in interface com.hazelcast.internal.util.MemoryInfoAccessor
Returns total amount allocated memory in the Java virtual machine in bytes.
getTotalMemory() - Method in class com.hazelcast.internal.util.RuntimeMemoryInfoAccessor
 
getTotalNormalizedHitCardinality() - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
getTotalNormalizedHitCardinality() - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
getTotalNormalizedHitCardinality() - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Returns the total normalized cardinality of the hits served by the index.
getTotalParkedOperationCount() - Method in class com.hazelcast.spi.impl.operationparker.impl.OperationParkerImpl
 
getTotalPhysical() - Method in class com.hazelcast.internal.memory.DefaultMemoryStats
 
getTotalPhysical() - Method in interface com.hazelcast.internal.memory.MemoryStats
Returns total physical memory available in OS.
getTotalPhysical() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
getTotalPublishedEventCount() - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
getTotalPublishedEventCount() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the total number of published events from this member
getTotalPublishLatency() - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
getTotalPublishLatency() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns the total latency of published wan events from this member by millisecond.
getTotalPutLatency() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
getTotalPutLatency() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
getTotalPutLatency() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
getTotalPutLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total latency of put operations.
getTotalRemoveLatency() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
getTotalRemoveLatency() - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
getTotalRemoveLatency() - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
 
getTotalRemoveLatency() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
getTotalRemoveLatency() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
getTotalRemoveLatency() - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Returns the total remove latency.
getTotalRemoveLatency() - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
getTotalRemoveLatency() - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Returns the total latency (in nanoseconds) of remove operations performed on the index.
getTotalRemoveLatency() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the total latency (in nanoseconds) of remove operations performed on the index.
getTotalRemoveLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total latency of remove operations.
getTotalRuns() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskStatisticsImpl
 
getTotalRuns() - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
Returns how many times the task was ran/called.
getTotalRunTime(TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskStatisticsImpl
 
getTotalRunTime(TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.ScheduledTaskStatistics
Returns the total amount of time the task spent while scheduled in.
getTotalSetLatency() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
getTotalSetLatency() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
getTotalSetLatency() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
getTotalSetLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total latency of set operations.
getTotalStartLatency() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
 
getTotalStartLatency() - Method in interface com.hazelcast.monitor.LocalExecutorStats
Returns the total start latency of operations started.
getTotalStorageMemoryCost(K, R) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
getTotalUpdateLatency() - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
getTotalUpdateLatency() - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
 
getTotalUpdateLatency() - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Returns the total update latency.
getTotalUpdateLatency() - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
getTotalUpdateLatency() - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Returns the total latency (in nanoseconds) of update operations performed on the index.
getTotalUpdateLatency() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the total latency (in nanoseconds) of update operations performed on the index.
getTotalValidWaitingOperationCount() - Method in class com.hazelcast.spi.impl.operationparker.impl.OperationParkerImpl
 
getTransaction() - Method in class com.hazelcast.client.impl.proxy.txn.xa.XATransactionContextProxy
 
getTransaction() - Method in class com.hazelcast.transaction.impl.SuspendedTransaction
 
getTransaction(TransactionContext) - Static method in class com.hazelcast.transaction.impl.xa.TransactionAccessor
 
getTransactionalObject(String, String) - Method in class com.hazelcast.client.impl.proxy.txn.TransactionContextProxy
 
getTransactionalObject(String, String) - Method in class com.hazelcast.client.impl.proxy.txn.xa.XATransactionContextProxy
 
getTransactionalObject(String, String) - Method in class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
 
getTransactionalObject(String, String) - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
 
getTransactionalObject(String, String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
Returns the transactional object instance with the specified name and service name.
getTransactionContext(UUID) - Method in interface com.hazelcast.client.impl.ClientEndpoint
 
getTransactionContext(UUID) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
getTransactionContext() - Method in class com.hazelcast.client.impl.proxy.txn.xa.XAResourceProxy
 
getTransactionContext(HazelcastInstance) - Static method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
Returns the transaction context for the given Hazelcast instance bounded to the current thread.
getTransactionContext() - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
Returns the transaction context
getTransactionContext() - Method in interface com.hazelcast.transaction.HazelcastXAResource
Returns the TransactionContext associated with the current thread.
getTransactionContext() - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
 
getTransactionId() - Method in class com.hazelcast.collection.impl.collection.TxCollectionItem
 
getTransactionId() - Method in class com.hazelcast.collection.impl.txnqueue.TxQueueItem
 
getTransactionLog() - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
getTransactionManager() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getTransactionManager() - Method in class com.hazelcast.client.impl.spi.ClientContext
 
getTransactionManagerService() - Method in interface com.hazelcast.client.impl.ClientEngine
 
getTransactionManagerService() - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
getTransactionManagerService() - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
getTransactionManagerService() - Method in interface com.hazelcast.spi.impl.NodeEngine
Gets the TransactionManagerService.
getTransactionManagerService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getTransactionRecords() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
 
getTransactionTimeout() - Method in class com.hazelcast.client.impl.proxy.txn.xa.XAResourceProxy
 
getTransactionTimeout() - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
 
getTransactionType() - Method in class com.hazelcast.transaction.impl.SuspendedTransaction
 
getTransactionType() - Method in interface com.hazelcast.transaction.impl.Transaction
 
getTransactionType() - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
getTransactionType() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
 
getTransactionType() - Method in class com.hazelcast.transaction.TransactionOptions
getTrustedInterfaces() - Method in class com.hazelcast.config.MulticastConfig
Gets the trusted interfaces.
getTryCount() - Method in class com.hazelcast.client.config.ClientFailoverConfig
 
getTryCount() - Method in class com.hazelcast.internal.cluster.impl.JoinRequest
 
getTryCount() - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Gets the try count; the number of times this operation can be retried.
getTryPauseMillis() - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Gets the pause time in milliseconds.
getTtl() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
getTtl() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
getTtl() - Method in interface com.hazelcast.core.EntryView
Returns the last set time to live in milliseconds.
getTtl() - Method in class com.hazelcast.map.impl.operation.PutIfAbsentOperation
 
getTtl() - Method in class com.hazelcast.map.impl.operation.PutIfAbsentWithExpiryOperation
 
getTtl() - Method in class com.hazelcast.map.impl.operation.PutOperation
 
getTtl() - Method in class com.hazelcast.map.impl.operation.PutTransientOperation
 
getTtl() - Method in class com.hazelcast.map.impl.operation.PutTransientWithExpiryOperation
 
getTtl() - Method in class com.hazelcast.map.impl.operation.PutWithExpiryOperation
 
getTtl() - Method in class com.hazelcast.map.impl.operation.SetOperation
 
getTtl() - Method in class com.hazelcast.map.impl.operation.SetWithExpiryOperation
 
getTtl() - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
getTtl() - Method in interface com.hazelcast.map.impl.record.Record
 
getTtl() - Method in class com.hazelcast.map.impl.record.RecordInfo
 
getTtl() - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
 
getTtl() - Method in class com.hazelcast.map.impl.SimpleEntryView
 
getTtl() - Method in class com.hazelcast.map.impl.wan.WanMapEntryView
 
getTtl() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
getTtl() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
getTtl() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
getTtl() - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
getTtl() - Method in interface com.hazelcast.spi.merge.MergingTTL
Returns the TTL of the merge data.
getTtlEvictionScheduler() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
getTtlMillis() - Method in class com.hazelcast.cp.internal.session.SessionResponse
 
getTtlMillis() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
getTxnId() - Method in class com.hazelcast.client.impl.proxy.txn.TransactionContextProxy
 
getTxnId() - Method in class com.hazelcast.client.impl.proxy.txn.xa.XATransactionContextProxy
 
getTxnId() - Method in class com.hazelcast.client.impl.proxy.txn.xa.XATransactionProxy
 
getTxnId() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntry
 
getTxnId() - Method in class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
 
getTxnId() - Method in class com.hazelcast.transaction.impl.SuspendedTransaction
 
getTxnId() - Method in interface com.hazelcast.transaction.impl.Transaction
 
getTxnId() - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
getTxnId() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
 
getTxnId() - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
 
getTxnId() - Method in class com.hazelcast.transaction.impl.xa.XATransactionDTO
 
getTxnId() - Method in interface com.hazelcast.transaction.TransactionContext
Gets the ID that uniquely identifies the transaction.
getTxnReservedCapacityCounter() - Method in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
 
getTxnReservedCapacityCounter() - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
 
getTxnReservedCapacityCounter() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
getType() - Method in enum com.hazelcast.cache.CacheEventType
 
getType() - Method in class com.hazelcast.cache.impl.journal.DeserializingEventJournalCacheEvent
 
getType() - Method in interface com.hazelcast.cache.impl.journal.EventJournalCacheEvent
Returns the event type.
getType() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
getType() - Method in class com.hazelcast.config.IndexConfig
Gets type of the index.
getType() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Returns the type of the Java KeyStore.
getType() - Method in class com.hazelcast.config.PermissionConfig
 
getType(String) - Static method in enum com.hazelcast.config.PermissionConfig.PermissionType
 
getType() - Method in enum com.hazelcast.core.EntryEventType
 
getType() - Method in enum com.hazelcast.core.ItemEventType
 
getType() - Method in class com.hazelcast.instance.EndpointQualifier
 
getType() - Method in class com.hazelcast.internal.ascii.AbstractTextCommand
 
getType() - Method in interface com.hazelcast.internal.ascii.TextCommand
 
getType() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateChange
 
getType() - Method in class com.hazelcast.internal.cluster.impl.MulticastJoiner
 
getType() - Method in class com.hazelcast.internal.cluster.impl.TcpIpJoiner
 
getType() - Method in interface com.hazelcast.internal.cluster.Joiner
 
getType() - Method in class com.hazelcast.internal.management.events.AddWanConfigIgnoredEvent
 
getType() - Method in interface com.hazelcast.internal.management.events.Event
 
getType() - Method in class com.hazelcast.internal.management.events.WanConfigurationAddedEvent
 
getType() - Method in class com.hazelcast.internal.management.events.WanConfigurationExtendedEvent
 
getType() - Method in class com.hazelcast.internal.management.events.WanConsistencyCheckFinishedEvent
 
getType() - Method in class com.hazelcast.internal.management.events.WanConsistencyCheckIgnoredEvent
 
getType() - Method in class com.hazelcast.internal.management.events.WanConsistencyCheckStartedEvent
 
getType() - Method in class com.hazelcast.internal.management.events.WanFullSyncFinishedEvent
 
getType() - Method in class com.hazelcast.internal.management.events.WanMerkleSyncFinishedEvent
 
getType() - Method in class com.hazelcast.internal.management.events.WanSyncIgnoredEvent
 
getType() - Method in class com.hazelcast.internal.management.events.WanSyncProgressUpdateEvent
 
getType() - Method in class com.hazelcast.internal.management.events.WanSyncStartedEvent
 
getType() - Method in class com.hazelcast.internal.management.request.ChangeClusterStateRequest
 
getType() - Method in class com.hazelcast.internal.management.request.ChangeWanStateRequest
 
getType() - Method in class com.hazelcast.internal.management.request.ClearWanQueuesRequest
 
getType() - Method in class com.hazelcast.internal.management.request.ClusterPropsRequest
 
getType() - Method in class com.hazelcast.internal.management.request.ConsoleCommandRequest
 
getType() - Method in interface com.hazelcast.internal.management.request.ConsoleRequest
 
getType() - Method in class com.hazelcast.internal.management.request.ExecuteScriptRequest
 
getType() - Method in class com.hazelcast.internal.management.request.ForceStartNodeRequest
 
getType() - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest
 
getType() - Method in class com.hazelcast.internal.management.request.GetClusterStateRequest
 
getType() - Method in class com.hazelcast.internal.management.request.GetMapEntryRequest
 
getType() - Method in class com.hazelcast.internal.management.request.GetMemberSystemPropertiesRequest
 
getType() - Method in class com.hazelcast.internal.management.request.MapConfigRequest
 
getType() - Method in class com.hazelcast.internal.management.request.MemberConfigRequest
 
getType() - Method in class com.hazelcast.internal.management.request.PromoteMemberRequest
 
getType() - Method in class com.hazelcast.internal.management.request.RunGcRequest
 
getType() - Method in class com.hazelcast.internal.management.request.ShutdownClusterRequest
 
getType() - Method in class com.hazelcast.internal.management.request.ThreadDumpRequest
 
getType() - Method in class com.hazelcast.internal.management.request.TriggerPartialStartRequest
 
getType() - Method in class com.hazelcast.internal.management.request.WanCheckConsistencyRequest
 
getType() - Method in interface com.hazelcast.internal.nio.Connection
Returns the ConnectionType of this Connection.
getType() - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
getType() - Method in class com.hazelcast.internal.serialization.impl.FieldDefinitionImpl
 
getType() - Method in class com.hazelcast.internal.serialization.impl.HeapData
 
getType() - Method in class com.hazelcast.map.impl.journal.DeserializingEventJournalMapEvent
 
getType() - Method in interface com.hazelcast.map.journal.EventJournalMapEvent
Returns the event type.
getType() - Method in interface com.hazelcast.nio.serialization.Data
Returns serialization type of binary form.
getType() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
getType() - Method in class com.hazelcast.scheduledexecutor.impl.TaskDefinition
 
getTypeClass() - Method in class com.hazelcast.config.SerializerConfig
Gets the type of the class that will be serialized via this implementation.
getTypeClassName() - Method in class com.hazelcast.config.SerializerConfig
Gets the name of the class that will be serialized via this implementation.
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ArrayBlockingQueueStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ArrayDequeStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ArrayListStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ArrayStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConcurrentHashMapStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConcurrentSkipListMapStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConcurrentSkipListSetStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.BooleanArraySerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.BooleanSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.ByteSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.CharArraySerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.CharSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.DoubleArraySerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.DoubleSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.FloatArraySerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.FloatSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.IntegerArraySerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.IntegerSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.LongArraySerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.LongSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.NullSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.ShortArraySerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.ShortSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.StringArraySerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.StringSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.TheByteArraySerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.UuidSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.CopyOnWriteArrayListStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.CopyOnWriteArraySetStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.DelayQueueStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.HashMapStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.HashSetStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.BigDecimalSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.BigIntegerSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.ClassSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.DateSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.EnumSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.ExternalizableSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.HazelcastJsonValueSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.JavaSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.LinkedBlockingQueueStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.LinkedHashMapStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.LinkedHashSetStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.LinkedListStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.LinkedTransferQueueStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.PriorityBlockingQueueStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.SynchronousQueueStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.TreeMapStreamSerializer
 
getTypeId() - Method in class com.hazelcast.internal.serialization.impl.TreeSetStreamSerializer
 
getTypeId() - Method in interface com.hazelcast.nio.serialization.Serializer
 
getTypeSize() - Method in enum com.hazelcast.nio.serialization.FieldType
 
getUncommittedEntryCountToRejectNewAppends() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
getUnit() - Method in class com.hazelcast.memory.MemorySize
Returns unit of memory size
getUnit() - Method in class com.hazelcast.scheduledexecutor.impl.TaskDefinition
 
getUnknownCollectionCount() - Method in class com.hazelcast.internal.memory.DefaultGarbageCollectorStats
 
getUnknownCollectionCount() - Method in interface com.hazelcast.internal.memory.GarbageCollectorStats
Returns collection count which cannot be identified as major or minor.
getUnknownCollectionCount() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
 
getUnknownCollectionTime() - Method in class com.hazelcast.internal.memory.DefaultGarbageCollectorStats
 
getUnknownCollectionTime() - Method in interface com.hazelcast.internal.memory.GarbageCollectorStats
Returns total collection time which cannot be identified as major or minor.
getUnknownCollectionTime() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
 
getUpdateCount() - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
getUpdateCount() - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
 
getUpdateCount() - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Returns the update count.
getUpdateCount() - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
getUpdateCount() - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Returns the number of update operations performed on the index.
getUpdateCount() - Method in interface com.hazelcast.monitor.LocalIndexStats
Returns the number of update operations performed on the index.
getUpdateCount() - Method in class com.hazelcast.wan.DistributedServiceWanEventCounters.DistributedObjectWanEventCounters
Returns the number of entry update events
getUpdateInterval() - Method in class com.hazelcast.config.ManagementCenterConfig
Gets the time frequency (in seconds) for which Management Center will take information from the Hazelcast cluster.
getUpdateTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
getUpstreamBuildInfo() - Method in class com.hazelcast.instance.BuildInfo
 
getUptime() - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
getURI() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
getURI() - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
 
getUriString() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
getUriString() - Method in class com.hazelcast.config.CacheConfig
Gets the URI string which is the global identifier for this ICache.
getUrl() - Method in class com.hazelcast.config.ManagementCenterConfig
Gets the URL where management center will work.
getUrl() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getUsage() - Method in class com.hazelcast.config.LoginModuleConfig
 
getUsedHeap() - Method in class com.hazelcast.internal.memory.DefaultMemoryStats
 
getUsedHeap() - Method in interface com.hazelcast.internal.memory.MemoryStats
Returns the amount of used memory in the JVM in bytes.
getUsedHeap() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
getUsedMemory() - Method in class com.hazelcast.internal.util.collection.HsaHeapMemoryManager
 
getUsedMetadata() - Method in class com.hazelcast.internal.memory.DefaultMemoryStats
 
getUsedMetadata() - Method in interface com.hazelcast.internal.memory.MemoryStats
 
getUsedMetadata() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
getUsedNative() - Method in class com.hazelcast.internal.memory.DefaultMemoryStats
 
getUsedNative() - Method in interface com.hazelcast.internal.memory.MemoryStats
Returns the amount of used native memory in current HazelcastInstance in bytes.
getUsedNative() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
getUserCodeDeploymentConfig() - Method in class com.hazelcast.client.config.ClientConfig
Get current configuration of User Code Deployment.
getUserCodeDeploymentConfig() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getUserCodeDeploymentConfig() - Method in class com.hazelcast.config.Config
Get current configuration of User Code Deployment.
getUserCodeDeploymentConfig() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getUserCodeDeploymentService() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getUserContext() - Method in class com.hazelcast.client.config.ClientConfig
 
getUserContext() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getUserContext() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getUserContext() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getUserContext() - Method in class com.hazelcast.config.Config
Returns the user supplied context.
getUserContext() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getUserContext() - Method in interface com.hazelcast.core.HazelcastInstance
Returns a ConcurrentMap that can be used to add user-context to the HazelcastInstance.
getUserContext() - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getUserContext() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getUserContext() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getUserData(String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
getUserExecutor() - Method in interface com.hazelcast.client.impl.spi.ClientExecutionService
 
getUserExecutor() - Method in class com.hazelcast.client.impl.spi.impl.ClientExecutionServiceImpl
 
getUserExecutor() - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocation
 
getUserExecutorQueueSize() - Method in class com.hazelcast.client.impl.spi.impl.ClientExecutionServiceImpl
 
getUserExpirationTime(long) - Method in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
Returns expiration time offset in terms of JVM clock.
getUserFilter() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getUsername() - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
 
getUserNameAttribute() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getUsernamePasswordIdentityConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
getUsernamePasswordIdentityConfig() - Method in class com.hazelcast.config.security.RealmConfig
 
getUserRegistrationId() - Method in class com.hazelcast.client.impl.spi.impl.listener.ClientRegistrationKey
 
getUserSearchScope() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
getUuid() - Method in interface com.hazelcast.client.Client
Returns a unique UUID for this client.
getUuid() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
getUuid() - Method in class com.hazelcast.client.impl.ClientEvent
 
getUuid() - Method in class com.hazelcast.client.impl.ClientImpl
 
getUuid() - Method in class com.hazelcast.client.impl.operations.OperationFactoryWrapper
 
getUuid() - Method in interface com.hazelcast.cluster.Endpoint
Returns the UUID of this endpoint
getUuid() - Method in class com.hazelcast.cluster.impl.AbstractMember
 
getUuid() - Method in interface com.hazelcast.cluster.Member
Returns the UUID of this member.
getUuid() - Method in interface com.hazelcast.cp.CPMember
Returns the UUID of this CP member.
getUuid() - Method in class com.hazelcast.cp.internal.CPMemberInfo
 
getUuid() - Method in interface com.hazelcast.cp.internal.raft.impl.RaftEndpoint
Returns the UUID of this Raft endpoint
getUuid() - Method in class com.hazelcast.cp.internal.RaftEndpointImpl
 
getUuid() - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
 
getUuid() - Method in class com.hazelcast.internal.cluster.MemberInfo
 
getUuid() - Method in class com.hazelcast.internal.management.events.AbstractWanAntiEntropyEventBase
 
getUuid() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataContainer
 
getUuid() - Method in class com.hazelcast.map.impl.querycache.publisher.PartitionAccumulatorRegistry
 
getUuid() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
getUuid() - Method in interface com.hazelcast.monitor.MemberState
Returns the UUID of this member.
getUuid() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
 
getUuid() - Method in class com.hazelcast.spi.impl.PortableCachePartitionLostEvent
 
getUuid() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
 
getUuid() - Method in class com.hazelcast.spi.impl.PortableItemEvent
 
getUuid() - Method in class com.hazelcast.spi.impl.PortableMapPartitionLostEvent
 
getUuid() - Method in class com.hazelcast.wan.ConsistencyCheckResult
 
getUuid() - Method in interface com.hazelcast.wan.WanAntiEntropyEvent
Returns the source cluster-wide unique ID for this anti-entropy event.
getUuid() - Method in interface com.hazelcast.wan.WanSyncStats
Returns the UUID of the synchronization.
getUuidOrNull(int) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataGenerator
 
getValidationTimeoutSeconds() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Returns configured validation timeout for hot-restart process.
getValue() - Method in interface com.hazelcast.cache.CacheEntryView
Gets the value of the cache entry.
getValue() - Method in class com.hazelcast.cache.impl.CacheEntry
 
getValue() - Method in class com.hazelcast.cache.impl.CacheEntryEventImpl
 
getValue() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
getValue() - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
 
getValue() - Method in class com.hazelcast.cache.impl.merge.entry.LazyCacheEntryView
 
getValue() - Method in class com.hazelcast.cache.impl.record.CacheDataRecord
 
getValue() - Method in class com.hazelcast.cache.impl.record.CacheObjectRecord
 
getValue() - Method in class com.hazelcast.cluster.MemberAttributeEvent
Returns the value for this MemberAttributeEvent.
getValue(int) - Static method in enum com.hazelcast.cluster.MemberAttributeOperationType
Gets the MemberAttributeOperationType by ID.
getValue() - Method in class com.hazelcast.collection.impl.collection.CollectionItem
 
getValue() - Method in class com.hazelcast.core.EntryEvent
Returns the value of the entry event.
getValue() - Method in interface com.hazelcast.core.EntryView
Returns the value of the entry.
getValue() - Method in class com.hazelcast.internal.ascii.memcache.IncrementCommand
 
getValue() - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
 
getValue() - Method in class com.hazelcast.internal.ascii.memcache.SetCommand
 
getValue() - Method in class com.hazelcast.internal.ascii.rest.RestValue
 
getValue() - Method in enum com.hazelcast.internal.ascii.TextCommandConstants.TextCommandType
 
getValue() - Method in class com.hazelcast.internal.crdt.pncounter.operations.CRDTTimestampedLong
 
getValue() - Method in interface com.hazelcast.internal.eviction.Evictable
Gets the value of this Evictable.
getValue() - Method in interface com.hazelcast.internal.eviction.EvictableEntryView
Gets the value of the entry.
getValue() - Method in class com.hazelcast.internal.journal.DeserializingEntry
 
getValue() - Method in class com.hazelcast.internal.json.JsonObject.Member
Returns the value of this member.
getValue() - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.CacheBrowserEntryView
 
getValue() - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
getValue() - Method in class com.hazelcast.internal.nearcache.impl.store.HeapNearCacheRecordMap.NearCacheEvictableSamplingEntry
 
getValue() - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap.SimpleEntry
 
getValue() - Method in class com.hazelcast.internal.util.scheduler.ScheduledEntry
 
getValue() - Method in class com.hazelcast.json.internal.JsonSchemaNameValue
Returns the description of the value stored in here
getValue() - Method in class com.hazelcast.map.EntryLoader.MetadataAwareValue
Returns the value
getValue() - Method in class com.hazelcast.map.impl.DataAwareEntryEvent
 
getValue(int) - Method in class com.hazelcast.map.impl.MapEntries
 
getValue() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntry
 
getValue() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
 
getValue() - Method in class com.hazelcast.map.impl.operation.WanEventHolder
 
getValue() - Method in class com.hazelcast.map.impl.query.QueryResultRow
 
getValue() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
getValue() - Method in class com.hazelcast.map.impl.querycache.event.LocalEntryEventData
 
getValue() - Method in interface com.hazelcast.map.impl.querycache.event.QueryCacheEventData
 
getValue() - Method in interface com.hazelcast.map.impl.querycache.subscriber.record.QueryCacheRecord
 
getValue() - Method in interface com.hazelcast.map.impl.record.Record
 
getValue() - Method in class com.hazelcast.map.impl.record.RecordReplicationInfo
 
getValue() - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
 
getValue() - Method in class com.hazelcast.map.impl.SimpleEntryView
 
getValue() - Method in class com.hazelcast.map.impl.wan.WanMapEntryView
 
getValue() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in its original unit.
getValue() - Method in class com.hazelcast.monitor.impl.LocalPNCounterStatsImpl
 
getValue() - Method in interface com.hazelcast.monitor.LocalPNCounterStats
Returns the current value of this PN counter
getValue() - Method in class com.hazelcast.query.impl.CachedQueryEntry
 
getValue() - Method in class com.hazelcast.query.impl.QueryableEntry
 
getValue() - Method in class com.hazelcast.query.impl.QueryEntry
 
getValue(int) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
 
getValue() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
 
getValue() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
getValue() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
getValue() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
getValue() - Method in class com.hazelcast.spi.impl.merge.AbstractCollectionMergingValueImpl
 
getValue() - Method in class com.hazelcast.spi.impl.merge.AbstractMergingEntryImpl
 
getValue() - Method in class com.hazelcast.spi.impl.merge.AbstractMergingValueImpl
 
getValue() - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
getValue() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
getValue() - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
getValue() - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
getValue() - Method in class com.hazelcast.spi.impl.merge.RingbufferMergingValueImpl
 
getValue() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.NormalResponse
Returns the object value of the operation.
getValue() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
 
getValue() - Method in interface com.hazelcast.spi.merge.MergingValue
Returns the merging value in the in-memory format of the backing data structure.
getValueClassName() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
getValueClassName() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getValueCollectionType() - Method in class com.hazelcast.config.MultiMapConfig
Gets the collection type for the values of this MultiMap.
getValueCollectionType(MultiMapContainer) - Method in class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
 
getValueComparatorOf(InMemoryFormat) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
getValueComparatorOf(InMemoryFormat) - Static method in class com.hazelcast.internal.util.comparators.ValueComparatorUtil
 
getValueComparatorOf(InMemoryFormat) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
getValueData() - Method in class com.hazelcast.map.impl.querycache.event.LocalEntryEventData
 
getValueData() - Method in class com.hazelcast.query.impl.CachedQueryEntry
 
getValueData() - Method in class com.hazelcast.query.impl.QueryableEntry
 
getValueData() - Method in class com.hazelcast.query.impl.QueryEntry
 
getValueInternal() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
getValueMetadata() - Method in class com.hazelcast.query.impl.Metadata
 
getValueOrCachedValue(Record, SerializationService) - Static method in class com.hazelcast.map.impl.record.Records
Return cached value where appropriate, otherwise return the actual value.
getValues() - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueSnapshot
 
getValues() - Method in class com.hazelcast.map.impl.MapValueCollection
 
getValues() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapValueCollection
 
getValueStartLocation() - Method in class com.hazelcast.json.internal.JsonSchemaTerminalNode
Points to the location where this object starts in underlying input.
getValueType() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
 
getValueType() - Method in class com.hazelcast.config.AbstractCacheConfig
 
getValueType() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the value type for this ICache.
getVectorClock() - Method in class com.hazelcast.internal.crdt.pncounter.operations.CRDTTimestampedLong
 
getVectorClocks() - Method in class com.hazelcast.internal.crdt.CRDTReplicationContainer
Returns the vector clocks for the CRDTs replicated by the replication operation.
getVersion() - Method in class com.hazelcast.cluster.impl.AbstractMember
 
getVersion() - Method in interface com.hazelcast.cluster.Member
Returns the Hazelcast codebase version of this member; this may or may not be different from the version reported by Cluster.getClusterVersion(), for example when a node with a different codebase version is added to an existing cluster.
getVersion() - Method in interface com.hazelcast.core.EntryView
Returns the version of the entry.
getVersion() - Method in class com.hazelcast.instance.BuildInfo
 
getVersion() - Method in class com.hazelcast.instance.impl.Node
Returns the codebase version of the node.
getVersion() - Method in class com.hazelcast.instance.JetBuildInfo
 
getVersion() - Method in class com.hazelcast.internal.cluster.impl.MembersView
 
getVersion() - Method in class com.hazelcast.internal.cluster.MemberInfo
 
getVersion() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
getVersion() - Method in interface com.hazelcast.internal.locksupport.LockResource
 
getVersion(Data) - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
getVersion() - Method in class com.hazelcast.internal.partition.impl.PartitionStateManager
 
getVersion() - Method in class com.hazelcast.internal.partition.PartitionRuntimeState
 
getVersion() - Method in class com.hazelcast.internal.partition.PartitionTableView
 
getVersion() - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
getVersion() - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
 
getVersion() - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
getVersion() - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
getVersion() - Method in class com.hazelcast.internal.serialization.impl.FieldDefinitionImpl
 
getVersion() - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
 
getVersion() - Method in interface com.hazelcast.internal.serialization.PortableContext
 
getVersion() - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
getVersion() - Method in interface com.hazelcast.map.impl.record.Record
 
getVersion() - Method in class com.hazelcast.map.impl.record.RecordInfo
 
getVersion() - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
 
getVersion() - Method in class com.hazelcast.map.impl.SimpleEntryView
 
getVersion() - Method in interface com.hazelcast.map.impl.tx.MapTxnOperation
 
getVersion() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
 
getVersion() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
 
getVersion() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
 
getVersion() - Method in class com.hazelcast.map.impl.wan.WanMapEntryView
 
getVersion() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
Returns the version.
getVersion() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
getVersion() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
getVersion() - Method in interface com.hazelcast.nio.serialization.PortableReader
 
getVersion() - Method in interface com.hazelcast.nio.VersionAware
 
getVersion() - Method in class com.hazelcast.replicatedmap.impl.operation.VersionResponsePair
 
getVersion() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
getVersion() - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
 
getVersion() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
getVersion() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
getVersion() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
getVersion() - Method in interface com.hazelcast.spi.impl.NodeEngine
Returns the codebase version of the node.
getVersion() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getVersion() - Method in interface com.hazelcast.spi.merge.MergingVersion
Returns the version of the merge data.
getWaitingRequests() - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
getWaitKey() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
 
getWaitKey() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
 
getWaitKey() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPeekOperation
 
getWaitKey() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferOperation
 
getWaitKey() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollOperation
 
getWaitKey() - Method in class com.hazelcast.durableexecutor.impl.operations.RetrieveAndDisposeResultOperation
 
getWaitKey() - Method in class com.hazelcast.durableexecutor.impl.operations.RetrieveResultOperation
 
getWaitKey() - Method in class com.hazelcast.internal.journal.EventJournalReadOperation
 
getWaitKey() - Method in class com.hazelcast.internal.locksupport.operations.LockOperation
 
getWaitKey() - Method in class com.hazelcast.map.impl.operation.AwaitMapFlushOperation
 
getWaitKey() - Method in class com.hazelcast.map.impl.operation.ContainsKeyOperation
 
getWaitKey() - Method in class com.hazelcast.map.impl.operation.GetEntryViewOperation
 
getWaitKey() - Method in class com.hazelcast.map.impl.operation.GetOperation
 
getWaitKey() - Method in class com.hazelcast.map.impl.operation.LockAwareOperation
 
getWaitKey() - Method in class com.hazelcast.multimap.impl.operations.AbstractBackupAwareMultiMapOperation
 
getWaitKey() - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
 
getWaitKey() - Method in class com.hazelcast.multimap.impl.operations.CountOperation
 
getWaitKey() - Method in class com.hazelcast.multimap.impl.operations.GetAllOperation
 
getWaitKey() - Method in class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
 
getWaitKey() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
 
getWaitKey() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
 
getWaitKey() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetResultOperation
 
getWaitKey() - Method in interface com.hazelcast.spi.impl.operationservice.BlockingOperation
 
getWaitKeyContainer(Object) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.BlockingResource
 
getWaitNotifyKey(ObjectNamespace, int) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
 
getWaitNotifyKey(ObjectNamespace, int) - Method in interface com.hazelcast.internal.journal.EventJournal
Return the WaitNotifyKey for objects waiting and notifying on the event journal.
getWaitNotifyKey(ObjectNamespace, int) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
 
getWaitTimeout() - Method in interface com.hazelcast.spi.impl.operationservice.BlockingOperation
 
getWaitTimeout() - Method in class com.hazelcast.spi.impl.operationservice.Operation
Returns the wait timeout in millis.
getWaitTimeouts() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
getWanConsumerConfig() - Method in class com.hazelcast.config.WanReplicationConfig
Returns the WAN consumer configuration for this WAN replication.
getWanEventCounter(String, String, String) - Method in class com.hazelcast.wan.impl.WanEventCounters
Returns the DistributedServiceWanEventCounters for the given serviceName
getWanMergePolicy() - Method in class com.hazelcast.map.impl.MapContainer
 
getWanProtocolVersion() - Method in interface com.hazelcast.nio.WanProtocolVersionAware
Returns the WAN protocol version.
getWanPublisherId(AbstractWanPublisherConfig) - Static method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
Returns the publisher ID for the given WAN publisher configuration which is then used for identifying the WAN publisher in a WAN replication scheme.
getWanReplicationConfig(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getWanReplicationConfig(String) - Method in class com.hazelcast.config.Config
Returns the WAN replication configuration with the given name.
getWanReplicationConfig(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getWanReplicationConfigs() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
getWanReplicationConfigs() - Method in class com.hazelcast.config.Config
Returns the map of WAN replication configurations, mapped by config name.
getWanReplicationConfigs() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
getWanReplicationDelegate() - Method in class com.hazelcast.map.impl.MapContainer
 
getWanReplicationPublishers(String) - Method in interface com.hazelcast.wan.impl.WanReplicationService
Creates a new WanReplicationPublisher by the given name.
getWanReplicationPublishers(String) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
 
getWanReplicationRef() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
getWanReplicationRef() - Method in class com.hazelcast.config.CacheConfig
 
getWanReplicationRef() - Method in class com.hazelcast.config.CacheSimpleConfig
Gets the WAN target replication reference.
getWanReplicationRef() - Method in class com.hazelcast.config.MapConfig
Gets the WAN target replication reference.
getWanReplicationRef() - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
getWanReplicationRef() - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
getWanReplicationService() - Method in interface com.hazelcast.spi.impl.NodeEngine
Gets the WanReplicationService.
getWanReplicationService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
getWanSyncConfig() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns the config for the WAN sync mechanism.
getWanSyncState() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
getWanSyncState() - Method in interface com.hazelcast.monitor.MemberState
 
getWanSyncState() - Method in interface com.hazelcast.wan.impl.WanReplicationService
Returns current status of WAN sync operation or null when there is no status.
getWanSyncState() - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
 
getWeightedItem(int) - Method in class com.hazelcast.internal.util.collection.WeightedEvictableList
 
getWhitelist() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
getWhitelistedPrefixes() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Return currently configured whitelist prefixes
getWorkQueueSize() - Method in class com.hazelcast.internal.util.executor.StripedExecutor
Returns the total number of tasks pending to be executed.
getWrappedMutableYamlNode(Node) - Static method in class com.hazelcast.internal.config.yaml.W3cDomUtil
Returns the the wrapped MutableYamlNode instance of the provided Node if the node is an instance of ElementAdapter and the YAML node wrapped by the node is a MutableYamlNode.
getWrappedYamlMapping(Node) - Static method in class com.hazelcast.internal.config.yaml.W3cDomUtil
Returns the the wrapped YamlMapping instance of the provided Node if the node is an instance of ElementAdapter and the YAML node wrapped by the node is a YamlMapping.
getWrappedYamlScalar(Node) - Static method in class com.hazelcast.internal.config.yaml.W3cDomUtil
Returns the the wrapped YamlScalar instance of the provided Node if the node is an instance of ElementAdapter and the YAML node wrapped by the node is a YamlScalar.
getWrappedYamlSequence(Node) - Static method in class com.hazelcast.internal.config.yaml.W3cDomUtil
Returns the the wrapped YamlSequence instance of the provided Node if the node is an instance of ElementAdapter and the YAML node wrapped by the node is a YamlSequence.
getWriteBatchSize() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
getWriteBatchSize() - Method in class com.hazelcast.config.MapStoreConfig
Returns the number of operations to be included in each batch processing round.
getWriteBehindQueue() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
getWriteDelaySeconds() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
getWriteDelaySeconds() - Method in class com.hazelcast.config.MapStoreConfig
Returns the number of seconds to delay the store writes.
getXAResource() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
getXAResource() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
getXaResource() - Method in class com.hazelcast.client.impl.proxy.txn.TransactionContextProxy
 
getXaResource() - Method in class com.hazelcast.client.impl.proxy.txn.xa.XATransactionContextProxy
 
getXAResource() - Method in interface com.hazelcast.core.HazelcastInstance
Gets xaResource which will participate in XATransaction.
getXAResource() - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
getXAResource() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
getXaResource() - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
 
getXaResource() - Method in interface com.hazelcast.transaction.TransactionContext
Deprecated.
since 3.5 please use HazelcastInstance.getXAResource()
getXid() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
 
getXid() - Method in class com.hazelcast.transaction.impl.xa.XATransactionDTO
 
getYamlNode() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
gigaBytes() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in giga-bytes.
global(boolean) - Method in class com.hazelcast.query.impl.Indexes.Builder
 
globalIndexes - Variable in class com.hazelcast.map.impl.MapContainer
 
GlobalIndexesStats - Class in com.hazelcast.monitor.impl
The implementation of internal indexes stats specialized for global indexes.
GlobalIndexesStats() - Constructor for class com.hazelcast.monitor.impl.GlobalIndexesStats
 
GlobalIndexOperationStats - Class in com.hazelcast.monitor.impl
The implementation of operation index stats specialized for global indexes.
GlobalIndexOperationStats() - Constructor for class com.hazelcast.monitor.impl.GlobalIndexOperationStats
 
GlobalMemoryAccessor - Interface in com.hazelcast.internal.memory
Accessor of global memory, both in CPU's native address space and on the Java heap.
GlobalMemoryAccessorRegistry - Class in com.hazelcast.internal.memory
Provides GlobalMemoryAccessor implementations by their GlobalMemoryAccessorType.
GlobalMemoryAccessorType - Enum in com.hazelcast.internal.memory
Types of GlobalMemoryAccessor implementations.
GlobalMutex - Class in com.hazelcast.internal.usercodedeployment.impl
This is used in Java 6 only.
GlobalMutex() - Constructor for class com.hazelcast.internal.usercodedeployment.impl.GlobalMutex
 
globalOrderingEnabled - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddTopicConfigCodec.RequestParameters
when true all nodes listening to the same topic get their messages in the same order
globalPartitioningStrategy - Variable in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
GlobalPerIndexStats - Class in com.hazelcast.monitor.impl
The implementation of internal index stats specialized for global indexes.
GlobalPerIndexStats(boolean, boolean) - Constructor for class com.hazelcast.monitor.impl.GlobalPerIndexStats
Constructs a new instance of global index stats.
GlobalQueryContextProvider - Class in com.hazelcast.query.impl
Provides the query context support for global indexes with disabled stats.
GlobalQueryContextProvider() - Constructor for class com.hazelcast.query.impl.GlobalQueryContextProvider
 
GlobalQueryContextProviderWithStats - Class in com.hazelcast.query.impl
Provides the query context support for global indexes with enabled stats.
GlobalQueryContextProviderWithStats() - Constructor for class com.hazelcast.query.impl.GlobalQueryContextProviderWithStats
 
GlobalQueryContextWithStats - Class in com.hazelcast.query.impl
Extends the basic query context to support the per-index stats tracking on behalf of global indexes.
GlobalQueryContextWithStats() - Constructor for class com.hazelcast.query.impl.GlobalQueryContextWithStats
 
GlobalSerializerConfig - Class in com.hazelcast.config
Contains the configuration for global serializer.
GlobalSerializerConfig() - Constructor for class com.hazelcast.config.GlobalSerializerConfig
 
GlobalSerializerConfig(GlobalSerializerConfig) - Constructor for class com.hazelcast.config.GlobalSerializerConfig
 
GO - Static variable in class com.hazelcast.client.impl.ClientTypes
Go client protocol ID
GO_GOB_SERIALIZATION_TYPE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
gotoAddress(long) - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray
Position this flyweight to the supplied base address.
gotoAddress(long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
gotoAddress(long) - Method in class com.hazelcast.internal.util.sort.MemArrayQuickSorter
Sets the base address to the supplied address.
gotoNew() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray
Allocate a new array and position this flyweight to its base address.
gotoNew() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
GRACEFUL_SHUTDOWN_MAX_WAIT - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
GracefulShutdownAwareService - Interface in com.hazelcast.internal.services
An interface that can be implemented by SPI services to participate in graceful shutdown process, such as moving their internal data to another node or releasing their allocated resources gracefully.
granted() - Method in class com.hazelcast.cp.internal.raft.impl.dto.PreVoteResponse
 
granted() - Method in class com.hazelcast.cp.internal.raft.impl.dto.VoteResponse
 
grantVote(RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.state.CandidateState
Persists vote for the endpoint during election.
greaterEqual(Comparable) - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
greaterEqual(Comparable) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
greaterEqual(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a greater than or equal to predicate that will pass items if the value stored under the given item attribute is greater than or equal to the given value.
GREATERLESS_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
GreaterLessPredicate - Class in com.hazelcast.query.impl.predicates
Greater Less Predicate
GreaterLessPredicate() - Constructor for class com.hazelcast.query.impl.predicates.GreaterLessPredicate
 
GreaterLessPredicate(String, Comparable, boolean, boolean) - Constructor for class com.hazelcast.query.impl.predicates.GreaterLessPredicate
 
greaterThan(Comparable) - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
greaterThan(Comparable) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
greaterThan(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a greater than predicate that will pass items if the value stored under the given item attribute is greater than the given value.
GROUP - Static variable in class com.hazelcast.spi.discovery.multicast.MulticastProperties
Property used to define zones for node filtering.
GROUP_ID - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
GROUP_MEMBERSHIP_CHANGE - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongAddAndGetCodec.RequestParameters
CP group id of this IAtomicLong instance.
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongAlterCodec.RequestParameters
CP group id of this IAtomicLong instance.
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongApplyCodec.RequestParameters
CP group id of this IAtomicLong instance.
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongCompareAndSetCodec.RequestParameters
CP group id of this IAtomicLong instance.
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndAddCodec.RequestParameters
CP group id of this IAtomicLong instance.
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndSetCodec.RequestParameters
CP group id of this IAtomicLong instance.
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetCodec.RequestParameters
CP group id of this IAtomicLong instance.
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefApplyCodec.RequestParameters
CP group id of this IAtomicReference instance.
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefCompareAndSetCodec.RequestParameters
CP group id of this IAtomicReference instance.
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefContainsCodec.RequestParameters
CP group id of this IAtomicReference instance.
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefGetCodec.RequestParameters
CP group id of this IAtomicReference instance.
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefSetCodec.RequestParameters
CP group id of this IAtomicReference instance.
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchAwaitCodec.RequestParameters
CP group id of this CountDownLatch instance
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchCountDownCodec.RequestParameters
CP group id of this CountDownLatch instance
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetCountCodec.RequestParameters
CP group id of this CountDownLatch instance
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetRoundCodec.RequestParameters
CP group id of this CountDownLatch instance
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchTrySetCountCodec.RequestParameters
CP group id of this CountDownLatch instance
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.CPGroupCreateCPGroupCodec.ResponseParameters
ID of the CP group that contains the CP object
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.CPGroupDestroyCPObjectCodec.RequestParameters
CP group id of this distributed object
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.CPSessionCloseSessionCodec.RequestParameters
ID of the CP group
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.CPSessionCreateSessionCodec.RequestParameters
ID of the CP group
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.CPSessionGenerateThreadIdCodec.RequestParameters
ID of the CP group
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.CPSessionHeartbeatSessionCodec.RequestParameters
ID of the CP group
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockGetLockOwnershipCodec.RequestParameters
CP group id of this FencedLock instance
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockLockCodec.RequestParameters
CP group id of this FencedLock instance
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockTryLockCodec.RequestParameters
CP group id of this FencedLock instance
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockUnlockCodec.RequestParameters
CP group id of this FencedLock instance
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreAcquireCodec.RequestParameters
CP group id of this ISemaphore instance
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreAvailablePermitsCodec.RequestParameters
CP group id of this ISemaphore instance
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreChangeCodec.RequestParameters
CP group id of this ISemaphore instance
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreDrainCodec.RequestParameters
CP group id of this ISemaphore instance
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreInitCodec.RequestParameters
CP group id of this ISemaphore instance
groupId - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreReleaseCodec.RequestParameters
CP group id of this ISemaphore instance
groupId() - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValue
 
groupId - Variable in class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
groupId - Variable in class com.hazelcast.cp.internal.operation.integration.AsyncRaftOp
 
groupId() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
 
groupId - Variable in class com.hazelcast.cp.internal.session.SessionAwareProxy
 
groupMembers() - Method in class com.hazelcast.cp.internal.raft.impl.log.SnapshotEntry
 
groupMembersLogIndex() - Method in class com.hazelcast.cp.internal.raft.impl.log.SnapshotEntry
 
GroupProperty - Class in com.hazelcast.spi.properties
Defines the name and default value for Hazelcast properties.

H

handle(int, Collection<CacheEventData>, int) - Method in class com.hazelcast.cache.impl.CacheEventListenerAdaptor
 
handle(BiFunction<? super V, Throwable, ? extends U>) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.CacheAddEntryListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.CacheAddInvalidationListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.CacheAddNearCacheInvalidationListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.CacheAddPartitionLostListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.ClientAddDistributedObjectListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.ClientAddMembershipListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionLostListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.ClientLocalBackupListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryAddListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.ListAddListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyWithPredicateCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerWithPredicateCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheEntryListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheInvalidationListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.MapAddPartitionLostListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerToKeyCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.QueueAddListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyWithPredicateCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerWithPredicateCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddNearCacheEntryListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.SetAddListenerCodec.AbstractEventHandler
 
handle(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.codec.TopicAddMessageListenerCodec.AbstractEventHandler
 
handle(E) - Method in interface com.hazelcast.client.impl.spi.EventHandler
 
handle(BulkGetCommand) - Method in class com.hazelcast.internal.ascii.memcache.BulkGetCommandProcessor
 
handle(DeleteCommand) - Method in class com.hazelcast.internal.ascii.memcache.DeleteCommandProcessor
 
handle(ErrorCommand) - Method in class com.hazelcast.internal.ascii.memcache.ErrorCommandProcessor
 
handle(GetCommand) - Method in class com.hazelcast.internal.ascii.memcache.GetCommandProcessor
Deprecated.
handle(IncrementCommand) - Method in class com.hazelcast.internal.ascii.memcache.IncrementCommandProcessor
 
handle(SetCommand) - Method in class com.hazelcast.internal.ascii.memcache.SetCommandProcessor
"set" means "store this data".
handle(SimpleCommand) - Method in class com.hazelcast.internal.ascii.memcache.SimpleCommandProcessor
 
handle(StatsCommand) - Method in class com.hazelcast.internal.ascii.memcache.StatsCommandProcessor
 
handle(TouchCommand) - Method in class com.hazelcast.internal.ascii.memcache.TouchCommandProcessor
 
handle(VersionCommand) - Method in class com.hazelcast.internal.ascii.memcache.VersionCommandProcessor
 
handle(NoOpCommand) - Method in class com.hazelcast.internal.ascii.NoOpCommandProcessor
 
handle(HttpDeleteCommand) - Method in class com.hazelcast.internal.ascii.rest.HttpDeleteCommandProcessor
 
handle(HttpGetCommand) - Method in class com.hazelcast.internal.ascii.rest.HttpGetCommandProcessor
 
handle(HttpHeadCommand) - Method in class com.hazelcast.internal.ascii.rest.HttpHeadCommandProcessor
 
handle(HttpPostCommand) - Method in class com.hazelcast.internal.ascii.rest.HttpPostCommandProcessor
 
handle(T) - Method in interface com.hazelcast.internal.ascii.TextCommandProcessor
 
handle(Data, UUID, UUID, long) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingHandler
Handles a single invalidation
handle(Collection<Data>, Collection<UUID>, Collection<UUID>, Collection<Long>) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingHandler
Handles batch invalidations
handle(T) - Method in interface com.hazelcast.internal.util.futures.ChainingFuture.ExceptionHandler
 
handle(T) - Method in class com.hazelcast.internal.util.iterator.RestartingMemberIterator
 
handle(T, boolean) - Method in interface com.hazelcast.map.impl.querycache.accumulator.AccumulatorHandler
Handles element.
handle(Sequenced, boolean) - Method in class com.hazelcast.map.impl.querycache.publisher.PublisherAccumulatorHandler
 
handle(BiFunction<? super V, Throwable, ? extends U>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
handle(BiFunction<? super V, Throwable, ? extends U>) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
handle(BiFunction<? super V, Throwable, ? extends U>) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
handleActiveCPMembers(RaftGroupId, long, Collection<CPMemberInfo>) - Method in class com.hazelcast.cp.internal.RaftService
 
handleAddListener(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleAddListener(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleAppendEntries(CPGroupId, AppendRequest, RaftEndpoint) - Method in class com.hazelcast.cp.internal.RaftService
 
handleAppendRequest(AppendRequest) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Handles AppendRequest sent by leader.
handleAppendRequest(AppendRequest) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
handleAppendResponse(AppendSuccessResponse) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Handles AppendSuccessResponse for a previously sent append request by this node.
handleAppendResponse(AppendFailureResponse) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Handles AppendFailureResponse for a previously sent append request by this node.
handleAppendResponse(AppendSuccessResponse) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
handleAppendResponse(AppendFailureResponse) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
handleAppendResponse(CPGroupId, AppendSuccessResponse, RaftEndpoint) - Method in class com.hazelcast.cp.internal.RaftService
 
handleAppendResponse(CPGroupId, AppendFailureResponse, RaftEndpoint) - Method in class com.hazelcast.cp.internal.RaftService
 
handleAsync(BiFunction<? super V, Throwable, ? extends U>) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
handleAsync(BiFunction<? super V, Throwable, ? extends U>, Executor) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
handleAsync(BiFunction<? super ClientMessage, Throwable, ? extends U>, Executor) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
handleAsync(BiFunction<? super V, Throwable, ? extends U>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
handleAsync(BiFunction<? super V, Throwable, ? extends U>, Executor) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
handleAsync(BiFunction<? super V, Throwable, ? extends U>) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
handleAsync(BiFunction<? super V, Throwable, ? extends U>, Executor) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
handleAsync(BiFunction<? super V, Throwable, ? extends U>) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
handleAsync(BiFunction<? super V, Throwable, ? extends U>, Executor) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
handleBackupEvent(long) - Method in class com.hazelcast.client.impl.protocol.codec.ClientLocalBackupListenerCodec.AbstractEventHandler
 
handleBackupEvent(long) - Method in class com.hazelcast.client.impl.spi.impl.SmartClientInvocationService.BackupEventHandler
 
handleCacheBatchInvalidationEvent(String, Collection<Data>, Collection<UUID>, Collection<UUID>, Collection<Long>) - Method in class com.hazelcast.client.impl.protocol.codec.CacheAddInvalidationListenerCodec.AbstractEventHandler
 
handleCacheBatchInvalidationEvent(String, Collection<Data>, Collection<UUID>, Collection<UUID>, Collection<Long>) - Method in class com.hazelcast.client.impl.protocol.codec.CacheAddNearCacheInvalidationListenerCodec.AbstractEventHandler
 
handleCacheEvent(int, Collection<CacheEventData>, int) - Method in class com.hazelcast.client.impl.protocol.codec.CacheAddEntryListenerCodec.AbstractEventHandler
 
handleCacheInvalidationEvent(String, Data, UUID, UUID, long) - Method in class com.hazelcast.client.impl.protocol.codec.CacheAddInvalidationListenerCodec.AbstractEventHandler
 
handleCacheInvalidationEvent(String, Data, UUID, UUID, long) - Method in class com.hazelcast.client.impl.protocol.codec.CacheAddNearCacheInvalidationListenerCodec.AbstractEventHandler
 
handleCachePartitionLostEvent(int, UUID) - Method in class com.hazelcast.client.impl.protocol.codec.CacheAddPartitionLostListenerCodec.AbstractEventHandler
 
handleClassNotFoundException(String) - Method in class com.hazelcast.internal.usercodedeployment.impl.ClassLocator
 
handleClassNotFoundException(String) - Method in class com.hazelcast.internal.usercodedeployment.UserCodeDeploymentService
 
handleClear(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleClear(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleClient(Node) - Method in class com.hazelcast.spring.HazelcastClientBeanDefinitionParser.SpringXmlBuilder
 
handleClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
handleCommand(String) - Method in class com.hazelcast.client.console.ClientConsoleApp
Handle a command.
handleCommand(String) - Method in class com.hazelcast.console.ConsoleApp
Handles a command.
handleCommand(String) - Method in class com.hazelcast.internal.management.ConsoleCommandHandler
Runs a command on the console.
handleCommonBeanAttributes(Node, BeanDefinitionBuilder, ParserContext) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleConfig(JsonObject) - Method in class com.hazelcast.internal.management.ClientBwListConfigHandler
Parses client B/W list filtering configuration in JSON format and applies the configuration.
handleConnectedSubscriber(UUID) - Method in class com.hazelcast.map.impl.querycache.publisher.DefaultPublisherContext
 
handleConnectedSubscriber(UUID) - Method in interface com.hazelcast.map.impl.querycache.publisher.PublisherContext
Handles a reconnected subscriber.
handleContains(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleContains(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleCount() - Method in class com.hazelcast.internal.networking.nio.NioThread
 
handleDataSerializableFactories(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleDestroy(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleDestroy(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleDisconnectedSubscriber(UUID) - Method in class com.hazelcast.map.impl.querycache.publisher.DefaultPublisherContext
 
handleDisconnectedSubscriber(UUID) - Method in interface com.hazelcast.map.impl.querycache.publisher.PublisherContext
Handles a disconnected subscriber.
handleDiscoveryStrategies(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleDistributedObjectEvent(String, String, String) - Method in class com.hazelcast.client.impl.protocol.codec.ClientAddDistributedObjectListenerCodec.AbstractEventHandler
 
handleEntryEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerCodec.AbstractEventHandler
 
handleEntryEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyCodec.AbstractEventHandler
 
handleEntryEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyWithPredicateCodec.AbstractEventHandler
 
handleEntryEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerWithPredicateCodec.AbstractEventHandler
 
handleEntryEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerCodec.AbstractEventHandler
 
handleEntryEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerToKeyCodec.AbstractEventHandler
 
handleEntryEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerCodec.AbstractEventHandler
 
handleEntryEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyCodec.AbstractEventHandler
 
handleEntryEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyWithPredicateCodec.AbstractEventHandler
 
handleEntryEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerWithPredicateCodec.AbstractEventHandler
 
handleEntryEvent(Data, Data, Data, Data, int, UUID, int) - Method in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddNearCacheEntryListenerCodec.AbstractEventHandler
 
handleEvent(Object) - Method in interface com.hazelcast.cache.impl.CacheEventListener
Cache Event handling function.
handleEvent(Object) - Method in class com.hazelcast.cache.impl.CacheEventListenerAdaptor
 
handleEvent(Object) - Method in class com.hazelcast.cache.impl.event.InternalCachePartitionLostListenerAdapter
 
handleEventMessage(ClientMessage) - Method in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
handleEventMessageOnCallingThread(ClientMessage) - Method in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
handleException(Throwable) - Method in interface com.hazelcast.internal.util.FutureUtil.ExceptionHandler
 
handleException(Throwable) - Method in class com.hazelcast.spi.impl.eventservice.impl.FutureUtilExceptionHandler
 
handleExceptionWhileProcessingMetadata(Member, Exception) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationMetaDataFetcher
 
handleExcludedMemberUuids(Address, Set<UUID>) - Method in interface com.hazelcast.internal.hotrestart.InternalHotRestartService
Handles the UUID set of excluded members only if this member is also excluded, and triggers the member force start process.
handleExcludedMemberUuids(Address, Set<UUID>) - Method in class com.hazelcast.internal.hotrestart.NoopInternalHotRestartService
 
handleExit() - Method in class com.hazelcast.console.ConsoleApp
 
handleExplicitSuspicion(MembersViewMetadata, Address) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
handleExplicitSuspicionTrigger(Address, int, MembersViewMetadata) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
handleHeartbeat(MembersViewMetadata, UUID, long) - Method in class com.hazelcast.internal.cluster.impl.ClusterHeartbeatManager
 
handleHeartbeatComplaint(MembersViewMetadata, MembersViewMetadata) - Method in class com.hazelcast.internal.cluster.impl.ClusterHeartbeatManager
 
handleHelp(String) - Method in class com.hazelcast.client.console.ClientConsoleApp
Handles the help command.
handleIMapBatchInvalidationEvent(Collection<Data>, Collection<UUID>, Collection<UUID>, Collection<Long>) - Method in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheEntryListenerCodec.AbstractEventHandler
 
handleIMapBatchInvalidationEvent(Collection<Data>, Collection<UUID>, Collection<UUID>, Collection<Long>) - Method in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheInvalidationListenerCodec.AbstractEventHandler
 
handleIMapInvalidationEvent(Data, UUID, UUID, long) - Method in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheEntryListenerCodec.AbstractEventHandler
 
handleIMapInvalidationEvent(Data, UUID, UUID, long) - Method in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheInvalidationListenerCodec.AbstractEventHandler
 
handleIndex(ManagedList<BeanDefinition>, Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleInstallSnapshot(InstallSnapshot) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Handles InstallSnapshot sent by leader.
handleInstallSnapshot(InstallSnapshot) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
handleInstances(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleInstances(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleInternalException(Throwable) - Method in class com.hazelcast.client.impl.proxy.ClientReliableMessageRunner
 
handleInternalException(Throwable) - Method in class com.hazelcast.topic.impl.reliable.MessageRunner
 
handleItemEvent(Data, UUID, int) - Method in class com.hazelcast.client.impl.protocol.codec.ListAddListenerCodec.AbstractEventHandler
 
handleItemEvent(Data, UUID, int) - Method in class com.hazelcast.client.impl.protocol.codec.QueueAddListenerCodec.AbstractEventHandler
 
handleItemEvent(Data, UUID, int) - Method in class com.hazelcast.client.impl.protocol.codec.SetAddListenerCodec.AbstractEventHandler
 
handleIterator(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleIterator(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleJavaSerializationFilter(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleJoinRequest(JoinRequest, Connection) - Method in class com.hazelcast.internal.cluster.impl.ClusterJoinManager
Handle a JoinRequestOp.
handleLicense(HttpGetCommand) - Method in class com.hazelcast.internal.ascii.rest.HttpGetCommandProcessor
License info is mplemented in the Enterprise GET command processor.
handleListAdd(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleListAdd(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleListAddMany(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleListAddMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleListContains(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleListContains(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleListRemove(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleListRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleListSet(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleListSet(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleLock(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleLostConnection() - Method in class com.hazelcast.internal.management.ClientBwListConfigHandler
Handles Management Center connection lost event: removes any client B/W list filtering.
handleMapDelete(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapDelete(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapEntries() - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapEntries() - Method in class com.hazelcast.console.ConsoleApp
 
handleMapEvict(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapEvict(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapGet(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapGet(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapGetAsync(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapGetAsync(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapGetMany(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapGetMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapGetMapEntry(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapGetMapEntry(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapKeys() - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapKeys() - Method in class com.hazelcast.console.ConsoleApp
 
handleMapLocalKeys() - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapLocalKeys() - Method in class com.hazelcast.console.ConsoleApp
 
handleMapLocalSize() - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapLocalSize() - Method in class com.hazelcast.console.ConsoleApp
 
handleMapLock(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapPartitionLostEvent(int, UUID) - Method in class com.hazelcast.client.impl.protocol.codec.MapAddPartitionLostListenerCodec.AbstractEventHandler
 
handleMapPut(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapPut(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapPutAsync(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapPutAsync(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapPutIfAbsent(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapPutIfAbsent(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapPutMany(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapPutMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapRemove(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapRemoveMany(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapRemoveMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapReplace(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapReplace(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapTryLock(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapTryLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapUnlock(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapUnlock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMapValues() - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMapValues() - Method in class com.hazelcast.console.ConsoleApp
 
handleMasterResponse(Address, Address) - Method in class com.hazelcast.internal.cluster.impl.ClusterJoinManager
Set master address, if required.
handleMastershipClaim(Address, UUID) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
handleMemberAttributeChangeEvent(Member, Collection<Member>, String, int, String) - Method in class com.hazelcast.client.impl.protocol.codec.ClientAddMembershipListenerCodec.AbstractEventHandler
 
handleMemberEvent(Member, int) - Method in class com.hazelcast.client.impl.protocol.codec.ClientAddMembershipListenerCodec.AbstractEventHandler
 
handleMemberListEvent(Collection<Member>) - Method in class com.hazelcast.client.impl.protocol.codec.ClientAddMembershipListenerCodec.AbstractEventHandler
 
handleMetadataGroupId(RaftGroupId) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
handleMultiMapEntries() - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMultiMapEntries() - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapGet(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMultiMapGet(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapKeys() - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMultiMapKeys() - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapLock(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMultiMapLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapPut(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMultiMapPut(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapRemove(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMultiMapRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapTryLock(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMultiMapTryLock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapUnlock(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMultiMapUnlock(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleMultiMapValues() - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleMultiMapValues() - Method in class com.hazelcast.console.ConsoleApp
 
handleNoSpaceLeft() - Method in class com.hazelcast.spi.impl.sequence.AbstractCallIdSequence
 
handleNoSpaceLeft() - Method in class com.hazelcast.spi.impl.sequence.CallIdSequenceWithBackpressure
 
handleNoSpaceLeft() - Method in class com.hazelcast.spi.impl.sequence.FailFastCallIdSequence
 
handlePartitionLostEvent(int, int, Address) - Method in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionLostListenerCodec.AbstractEventHandler
 
handlePartitions(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handlePartitions(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handlePartitionsEvent(Collection<Map.Entry<Address, List<Integer>>>, int) - Method in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionListenerCodec.AbstractEventHandler
 
handlePortableFactories(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handlePreVoteRequest(PreVoteRequest) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Handles PreVoteRequest sent by another follower.
handlePreVoteRequest(PreVoteRequest) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
handlePreVoteRequest(CPGroupId, PreVoteRequest, RaftEndpoint) - Method in class com.hazelcast.cp.internal.RaftService
 
handlePreVoteResponse(PreVoteResponse) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Handles PreVoteResponse for a previously sent request by this node.
handlePreVoteResponse(PreVoteResponse) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
handlePreVoteResponse(CPGroupId, PreVoteResponse, RaftEndpoint) - Method in class com.hazelcast.cp.internal.RaftService
 
handleProcessingFailure(Throwable) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
handleProperties(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleQCapacity(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleQCapacity(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQOffer(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleQOffer(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQOfferMany(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleQOfferMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQPeek(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleQPeek(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQPoll(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleQPoll(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQPollMany(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleQPollMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQTake(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleQTake(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleQueryCacheBatchEvent(Collection<QueryCacheEventData>, String, int) - Method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryAddListenerCodec.AbstractEventHandler
 
handleQueryCacheSingleEvent(QueryCacheEventData) - Method in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryAddListenerCodec.AbstractEventHandler
 
handler - Variable in class com.hazelcast.map.impl.querycache.accumulator.BasicAccumulator
 
handlerAdded() - Method in class com.hazelcast.client.impl.connection.nio.ClientProtocolEncoder
 
handlerAdded() - Method in class com.hazelcast.client.impl.protocol.util.ClientMessageDecoder
 
handlerAdded() - Method in class com.hazelcast.client.impl.protocol.util.ClientMessageEncoder
 
handlerAdded() - Method in class com.hazelcast.internal.networking.ChannelHandler
Gets called when this ChannelHandler is added to the pipeline.
handlerAdded() - Method in class com.hazelcast.internal.nio.ascii.TextDecoder
 
handlerAdded() - Method in class com.hazelcast.internal.nio.ascii.TextEncoder
 
handlerAdded() - Method in class com.hazelcast.internal.nio.tcp.MemberProtocolEncoder
 
handlerAdded() - Method in class com.hazelcast.internal.nio.tcp.PacketDecoder
 
handlerAdded() - Method in class com.hazelcast.internal.nio.tcp.PacketEncoder
 
handlerAdded() - Method in class com.hazelcast.internal.nio.tcp.SingleProtocolDecoder
 
handlerAdded() - Method in class com.hazelcast.internal.nio.tcp.UnifiedProtocolDecoder
 
handlerAdded() - Method in class com.hazelcast.internal.nio.tcp.UnifiedProtocolEncoder
 
handleRegistration(Registration) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
handleRejection(BulkGetCommand) - Method in class com.hazelcast.internal.ascii.memcache.BulkGetCommandProcessor
 
handleRejection(DeleteCommand) - Method in class com.hazelcast.internal.ascii.memcache.DeleteCommandProcessor
 
handleRejection(ErrorCommand) - Method in class com.hazelcast.internal.ascii.memcache.ErrorCommandProcessor
 
handleRejection(GetCommand) - Method in class com.hazelcast.internal.ascii.memcache.GetCommandProcessor
 
handleRejection(IncrementCommand) - Method in class com.hazelcast.internal.ascii.memcache.IncrementCommandProcessor
 
handleRejection(SetCommand) - Method in class com.hazelcast.internal.ascii.memcache.SetCommandProcessor
 
handleRejection(SimpleCommand) - Method in class com.hazelcast.internal.ascii.memcache.SimpleCommandProcessor
 
handleRejection(StatsCommand) - Method in class com.hazelcast.internal.ascii.memcache.StatsCommandProcessor
 
handleRejection(TouchCommand) - Method in class com.hazelcast.internal.ascii.memcache.TouchCommandProcessor
 
handleRejection(VersionCommand) - Method in class com.hazelcast.internal.ascii.memcache.VersionCommandProcessor
 
handleRejection(NoOpCommand) - Method in class com.hazelcast.internal.ascii.NoOpCommandProcessor
 
handleRejection(HttpDeleteCommand) - Method in class com.hazelcast.internal.ascii.rest.HttpDeleteCommandProcessor
 
handleRejection(HttpGetCommand) - Method in class com.hazelcast.internal.ascii.rest.HttpGetCommandProcessor
 
handleRejection(HttpHeadCommand) - Method in class com.hazelcast.internal.ascii.rest.HttpHeadCommandProcessor
 
handleRejection(HttpPostCommand) - Method in class com.hazelcast.internal.ascii.rest.HttpPostCommandProcessor
 
handleRejection(T) - Method in interface com.hazelcast.internal.ascii.TextCommandProcessor
 
handleRemoveListener(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleRemoveListener(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleResponse() - Method in class com.hazelcast.cp.internal.raft.impl.handler.AbstractResponseHandlerTask
 
handleResponse() - Method in class com.hazelcast.cp.internal.raft.impl.handler.AppendFailureResponseHandlerTask
 
handleResponse() - Method in class com.hazelcast.cp.internal.raft.impl.handler.AppendSuccessResponseHandlerTask
 
handleResponse() - Method in class com.hazelcast.cp.internal.raft.impl.handler.PreVoteResponseHandlerTask
 
handleResponse() - Method in class com.hazelcast.cp.internal.raft.impl.handler.VoteResponseHandlerTask
 
handlers - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetAllScheduledFuturesCodec.ResponseParameters
A list of scheduled task handlers used to construct the future proxies.
handlers() - Method in class com.hazelcast.internal.networking.nio.NioInboundPipeline
 
handlers() - Method in class com.hazelcast.internal.networking.nio.NioOutboundPipeline
 
handlers() - Method in class com.hazelcast.internal.networking.nio.NioPipeline
Returns an Iterable that can iterate over each ChannelHandler of the pipeline.
HandlerStatus - Enum in com.hazelcast.internal.networking
 
handleSerialization(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleSerializers(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleSetAdd(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleSetAdd(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleSetAddMany(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleSetAddMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleSetRemove(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleSetRemove(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleSetRemoveMany(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleSetRemoveMany(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleShutdown() - Method in class com.hazelcast.console.ConsoleApp
 
handleSize(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleSize(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleSnapshot(CPGroupId, InstallSnapshot, RaftEndpoint) - Method in class com.hazelcast.cp.internal.RaftService
 
handleSocketInterceptorConfig(Node, BeanDefinitionBuilder) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleSpringAware() - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
handleTopicEvent(Data, long, UUID) - Method in class com.hazelcast.client.impl.protocol.codec.TopicAddMessageListenerCodec.AbstractEventHandler
 
handleTopicPublish(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
handleTopicPublish(String[]) - Method in class com.hazelcast.console.ConsoleApp
 
handleTriggerLeaderElection(TriggerLeaderElection) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
 
handleTriggerLeaderElection(TriggerLeaderElection) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
handleTriggerLeaderElection(CPGroupId, TriggerLeaderElection, RaftEndpoint) - Method in class com.hazelcast.cp.internal.RaftService
 
handleVoteRequest(VoteRequest) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Handles VoteRequest sent by a candidate.
handleVoteRequest(VoteRequest) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
handleVoteRequest(CPGroupId, VoteRequest, RaftEndpoint) - Method in class com.hazelcast.cp.internal.RaftService
 
handleVoteResponse(VoteResponse) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Handles VoteResponse for a previously sent vote request by this node.
handleVoteResponse(VoteResponse) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
handleVoteResponse(CPGroupId, VoteResponse, RaftEndpoint) - Method in class com.hazelcast.cp.internal.RaftService
 
hardFlush() - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
Flushes write-behind-queue into map-store in calling thread.
hardFlush() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
hardFlush() - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
has(String) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
HAS_ONGOING_MIGRATION - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
hasActiveInvocation(Operation) - Static method in class com.hazelcast.spi.impl.operationservice.OperationAccessor
 
hasAny() - Method in class com.hazelcast.json.internal.JsonPattern
Checks if this pattern has "any" keyword.
hasAnyQueryCacheRegistered() - Method in class com.hazelcast.client.impl.querycache.subscriber.QueryCacheToListenerMapper
 
hasAnyRecordStore() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
 
hasAttribute(String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
hasAttributeNS(String, String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
hasAttributes() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
hasChildNodes() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
hasDefiniteSize() - Method in enum com.hazelcast.nio.serialization.FieldType
 
hasEnoughCapacity(int) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
hasEnoughCapacity(int) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
 
hasEnoughCapacity() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Returns if this queue can accommodate one item.
hasEnoughCapacity(int) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Returns if this queue can accommodate for delta items.
hasEntries(Store) - Method in class com.hazelcast.spi.impl.merge.AbstractSplitBrainHandlerService
Checks if the given Store has entries.
hasEntryWithCustomExpiration - Variable in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
hasEntryWithExpiration - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
hasEventJournal(ObjectNamespace) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
Returns true if the object has a configured and enabled event journal.
hasEventJournal(ObjectNamespace) - Method in interface com.hazelcast.internal.journal.EventJournal
Returns true if the object has a configured and enabled event journal.
hasEventJournal(ObjectNamespace) - Method in interface com.hazelcast.map.impl.journal.MapEventJournal
Returns true if the object has a configured and enabled event journal.
hasEventJournal(ObjectNamespace) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
 
hasEventListener(String) - Method in interface com.hazelcast.map.impl.event.MapEventPublisher
Returns true if there is at least one listener registered for the specified mapName.
hasEventListener(String) - Method in class com.hazelcast.map.impl.event.MapEventPublisherImpl
 
hasEventRegistration(String, String) - Method in interface com.hazelcast.spi.impl.eventservice.EventService
Returns true if a listener is registered with the specified service name and topic.
hasEventRegistration(String, String) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
hasExpiredKeyToSendBackup(CachePartitionSegment) - Method in class com.hazelcast.cache.impl.eviction.CacheClearExpiredRecordsTask
 
hasExpiredKeyToSendBackup(T) - Method in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
hasExpiredKeyToSendBackup(PartitionContainer) - Method in class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
 
hasField(String) - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
 
hasField(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
hasField(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
Checks if there exists a FieldDefinition with the given fieldName.
hasField(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
hash - Variable in class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorAddCodec.RequestParameters
64bit hash code value to add
hash64() - Method in class com.hazelcast.internal.serialization.impl.HeapData
 
hash64() - Method in interface com.hazelcast.nio.serialization.Data
Returns 64-bit hash code for this Data object.
HASH_MAP_ADAPTER - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
hashCode() - Method in class com.hazelcast.aggregation.impl.AbstractAggregator
 
hashCode() - Method in class com.hazelcast.aggregation.impl.BigDecimalAverageAggregator
 
hashCode() - Method in class com.hazelcast.aggregation.impl.BigDecimalSumAggregator
 
hashCode() - Method in class com.hazelcast.aggregation.impl.BigIntegerAverageAggregator
 
hashCode() - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
hashCode() - Method in class com.hazelcast.aggregation.impl.CountAggregator
 
hashCode() - Method in class com.hazelcast.aggregation.impl.DistinctValuesAggregator
 
hashCode() - Method in class com.hazelcast.aggregation.impl.DoubleAverageAggregator
 
hashCode() - Method in class com.hazelcast.aggregation.impl.DoubleSumAggregator
 
hashCode() - Method in class com.hazelcast.aggregation.impl.FixedSumAggregator
 
hashCode() - Method in class com.hazelcast.aggregation.impl.FloatingPointSumAggregator
 
hashCode() - Method in class com.hazelcast.aggregation.impl.IntegerAverageAggregator
 
hashCode() - Method in class com.hazelcast.aggregation.impl.IntegerSumAggregator
 
hashCode() - Method in class com.hazelcast.aggregation.impl.LongAverageAggregator
 
hashCode() - Method in class com.hazelcast.aggregation.impl.LongSumAggregator
 
hashCode() - Method in class com.hazelcast.aggregation.impl.MaxAggregator
 
hashCode() - Method in class com.hazelcast.aggregation.impl.MaxByAggregator
 
hashCode() - Method in class com.hazelcast.aggregation.impl.MinAggregator
 
hashCode() - Method in class com.hazelcast.aggregation.impl.MinByAggregator
 
hashCode() - Method in class com.hazelcast.aggregation.impl.NumberAverageAggregator
 
hashCode() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
hashCode() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
 
hashCode() - Method in class com.hazelcast.cache.impl.CachePartitionEventData
 
hashCode() - Method in class com.hazelcast.cache.impl.DeferredValue
 
hashCode() - Method in class com.hazelcast.cache.impl.event.CachePartitionLostEventFilter
 
hashCode() - Method in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
 
hashCode() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
 
hashCode() - Method in class com.hazelcast.client.config.ClientCloudConfig
 
hashCode() - Method in class com.hazelcast.client.config.ClientConfig
 
hashCode() - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
 
hashCode() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
 
hashCode() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
hashCode() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
hashCode() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
 
hashCode() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
hashCode() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
hashCode() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
 
hashCode() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
hashCode() - Method in class com.hazelcast.client.config.SocketOptions
 
hashCode() - Method in class com.hazelcast.client.impl.client.DistributedObjectInfo
 
hashCode() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
hashCode() - Method in class com.hazelcast.client.impl.protocol.ClientMessage.Frame
 
hashCode() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
hashCode() - Method in class com.hazelcast.client.impl.spi.ClientProxy
 
hashCode() - Method in class com.hazelcast.client.impl.spi.impl.listener.ClientEventRegistration
 
hashCode() - Method in class com.hazelcast.client.impl.spi.impl.listener.ClientRegistrationKey
 
hashCode() - Method in class com.hazelcast.cluster.Address
 
hashCode() - Method in class com.hazelcast.cluster.impl.AbstractMember
 
hashCode() - Method in class com.hazelcast.cluster.impl.VectorClock
 
hashCode() - Method in class com.hazelcast.collection.impl.collection.CollectionEventFilter
 
hashCode() - Method in class com.hazelcast.collection.impl.collection.CollectionItem
 
hashCode() - Method in class com.hazelcast.collection.impl.collection.TxCollectionItem
 
hashCode() - Method in class com.hazelcast.collection.impl.queue.QueueEventFilter
 
hashCode() - Method in class com.hazelcast.collection.impl.queue.QueueItem
 
hashCode() - Method in class com.hazelcast.collection.impl.queue.QueueWaitNotifyKey
 
hashCode() - Method in class com.hazelcast.collection.impl.txnqueue.TxQueueItem
 
hashCode() - Method in class com.hazelcast.config.AbstractCacheConfig
 
hashCode() - Method in class com.hazelcast.config.AbstractWanPublisherConfig
 
hashCode() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
hashCode() - Method in class com.hazelcast.config.AttributeConfig
 
hashCode() - Method in class com.hazelcast.config.CacheConfig
 
hashCode() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleConfig
 
hashCode() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
hashCode() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
hashCode() - Method in class com.hazelcast.config.ClassFilter
 
hashCode() - Method in class com.hazelcast.config.CollectionConfig
 
hashCode() - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
hashCode() - Method in class com.hazelcast.config.DiscoveryConfig
 
hashCode() - Method in class com.hazelcast.config.DurableExecutorConfig
 
hashCode() - Method in class com.hazelcast.config.EncryptionAtRestConfig
 
hashCode() - Method in class com.hazelcast.config.EntryListenerConfig
 
hashCode() - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
hashCode() - Method in class com.hazelcast.config.EventJournalConfig
 
hashCode() - Method in class com.hazelcast.config.EvictionConfig
 
hashCode() - Method in class com.hazelcast.config.ExecutorConfig
 
hashCode() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
hashCode() - Method in class com.hazelcast.config.GlobalSerializerConfig
 
hashCode() - Method in class com.hazelcast.config.HotRestartConfig
 
hashCode() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
 
hashCode() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
hashCode() - Method in class com.hazelcast.config.IndexConfig
 
hashCode() - Method in class com.hazelcast.config.InterfacesConfig
 
hashCode() - Method in class com.hazelcast.config.ItemListenerConfig
 
hashCode() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
 
hashCode() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
hashCode() - Method in class com.hazelcast.config.ListenerConfig
 
hashCode() - Method in class com.hazelcast.config.LoginModuleConfig
 
hashCode() - Method in class com.hazelcast.config.MapConfig
 
hashCode() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
 
hashCode() - Method in class com.hazelcast.config.MapStoreConfig
 
hashCode() - Method in class com.hazelcast.config.matcher.MatchingPointConfigPatternMatcher
 
hashCode() - Method in class com.hazelcast.config.matcher.RegexConfigPatternMatcher
 
hashCode() - Method in class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
 
hashCode() - Method in class com.hazelcast.config.MaxSizeConfig
 
hashCode() - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
hashCode() - Method in class com.hazelcast.config.MemberGroupConfig
 
hashCode() - Method in class com.hazelcast.config.MergePolicyConfig
 
hashCode() - Method in class com.hazelcast.config.MerkleTreeConfig
 
hashCode() - Method in class com.hazelcast.config.MetricsConfig
 
hashCode() - Method in class com.hazelcast.config.MulticastConfig
 
hashCode() - Method in class com.hazelcast.config.MultiMapConfig
 
hashCode() - Method in class com.hazelcast.config.NativeMemoryConfig
 
hashCode() - Method in class com.hazelcast.config.NearCacheConfig
 
hashCode() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
hashCode() - Method in class com.hazelcast.config.PartitionGroupConfig
 
hashCode() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
hashCode() - Method in class com.hazelcast.config.PermissionConfig
 
hashCode() - Method in class com.hazelcast.config.PermissionPolicyConfig
 
hashCode() - Method in class com.hazelcast.config.PNCounterConfig
 
hashCode() - Method in class com.hazelcast.config.PredicateConfig
 
hashCode() - Method in class com.hazelcast.config.QueryCacheConfig
 
hashCode() - Method in class com.hazelcast.config.QueueConfig
 
hashCode() - Method in class com.hazelcast.config.QueueStoreConfig
 
hashCode() - Method in class com.hazelcast.config.ReliableTopicConfig
 
hashCode() - Method in class com.hazelcast.config.ReplicatedMapConfig
 
hashCode() - Method in class com.hazelcast.config.RingbufferConfig
 
hashCode() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
hashCode() - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
hashCode() - Method in class com.hazelcast.config.security.CredentialsIdentityConfig
 
hashCode() - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
 
hashCode() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
hashCode() - Method in class com.hazelcast.config.security.RealmConfig
 
hashCode() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
 
hashCode() - Method in class com.hazelcast.config.security.TokenIdentityConfig
 
hashCode() - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
 
hashCode() - Method in class com.hazelcast.config.SecurityConfig
 
hashCode() - Method in class com.hazelcast.config.SerializationConfig
 
hashCode() - Method in class com.hazelcast.config.SerializerConfig
 
hashCode() - Method in class com.hazelcast.config.ServiceConfig
 
hashCode() - Method in class com.hazelcast.config.ServicesConfig
 
hashCode() - Method in class com.hazelcast.config.SocketInterceptorConfig
 
hashCode() - Method in class com.hazelcast.config.SSLConfig
 
hashCode() - Method in class com.hazelcast.config.TcpIpConfig
 
hashCode() - Method in class com.hazelcast.config.TopicConfig
 
hashCode() - Method in class com.hazelcast.config.VaultSecureStoreConfig
 
hashCode() - Method in class com.hazelcast.config.WanConsumerConfig
 
hashCode() - Method in class com.hazelcast.config.WanReplicationConfig
 
hashCode() - Method in class com.hazelcast.config.WanReplicationRef
 
hashCode() - Method in class com.hazelcast.config.WanSyncConfig
 
hashCode() - Method in class com.hazelcast.core.HazelcastJsonValue
 
hashCode() - Method in class com.hazelcast.core.LifecycleEvent
 
hashCode() - Method in class com.hazelcast.cp.internal.CPMemberInfo
 
hashCode() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.AwaitInvocationKey
 
hashCode() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockEndpoint
 
hashCode() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockInvocationKey
 
hashCode() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.AcquireInvocationKey
 
hashCode() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreEndpoint
 
hashCode() - Method in class com.hazelcast.cp.internal.RaftEndpointImpl
 
hashCode() - Method in class com.hazelcast.cp.internal.RaftGroupId
 
hashCode() - Method in class com.hazelcast.cp.internal.session.CPSessionInfo
 
hashCode() - Method in class com.hazelcast.durableexecutor.impl.operations.DurableExecutorWaitNotifyKey
 
hashCode() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
hashCode() - Method in class com.hazelcast.instance.EndpointQualifier
 
hashCode() - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
hashCode() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
hashCode() - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
 
hashCode() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateChange
 
hashCode() - Method in class com.hazelcast.internal.cluster.impl.MembersViewMetadata
 
hashCode() - Method in class com.hazelcast.internal.cluster.MemberInfo
 
hashCode() - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
hashCode() - Method in class com.hazelcast.internal.eviction.EvictionPolicyComparator
 
hashCode() - Method in class com.hazelcast.internal.json.JsonArray
 
hashCode() - Method in class com.hazelcast.internal.json.JsonObject
 
hashCode() - Method in class com.hazelcast.internal.json.JsonObject.Member
 
hashCode() - Method in class com.hazelcast.internal.json.JsonValue
 
hashCode() - Method in class com.hazelcast.internal.json.Location
 
hashCode() - Method in class com.hazelcast.internal.locksupport.LockWaitNotifyKey
 
hashCode() - Method in class com.hazelcast.internal.networking.ChannelOption
 
hashCode() - Method in class com.hazelcast.internal.nio.Packet
 
hashCode() - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
hashCode() - Method in class com.hazelcast.internal.partition.impl.ReplicaFragmentSyncInfo
 
hashCode() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
hashCode() - Method in class com.hazelcast.internal.partition.NonFragmentedServiceNamespace
 
hashCode() - Method in class com.hazelcast.internal.partition.PartitionReplica
 
hashCode() - Method in class com.hazelcast.internal.partition.PartitionTableView
 
hashCode() - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
 
hashCode() - Method in class com.hazelcast.internal.serialization.impl.FieldDefinitionImpl
 
hashCode() - Method in class com.hazelcast.internal.serialization.impl.HeapData
 
hashCode() - Method in class com.hazelcast.internal.services.DistributedObjectNamespace
 
hashCode() - Method in class com.hazelcast.internal.util.BiTuple
 
hashCode() - Method in class com.hazelcast.internal.util.collection.IntHashSet
 
hashCode() - Method in class com.hazelcast.internal.util.collection.LongHashSet
hashCode() - Method in class com.hazelcast.internal.util.collection.OAHashSet
 
hashCode() - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap.SimpleEntry
 
hashCode(Object...) - Static method in class com.hazelcast.internal.util.HashUtil
Hash code for multiple objects using Arrays.hashCode(Object[]).
hashCode() - Method in class com.hazelcast.internal.util.ItemCounter
 
hashCode() - Method in class com.hazelcast.internal.util.MutableLong
 
hashCode() - Method in class com.hazelcast.internal.util.SampleableConcurrentHashMap.SamplingEntry
 
hashCode() - Method in class com.hazelcast.internal.util.scheduler.ScheduledEntry
 
hashCode() - Method in class com.hazelcast.internal.util.TriTuple
 
hashCode() - Method in class com.hazelcast.json.internal.JsonPattern
 
hashCode() - Method in class com.hazelcast.json.internal.JsonSchemaNameValue
 
hashCode() - Method in class com.hazelcast.json.internal.JsonSchemaStructNode
 
hashCode() - Method in class com.hazelcast.json.internal.JsonSchemaTerminalNode
 
hashCode() - Method in class com.hazelcast.map.eviction.LFUEvictionPolicy
 
hashCode() - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
 
hashCode() - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
 
hashCode() - Method in class com.hazelcast.map.impl.EntryEventFilter
 
hashCode() - Method in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
 
hashCode() - Method in class com.hazelcast.map.impl.LazyMapEntry
 
hashCode() - Method in class com.hazelcast.map.impl.MapEntrySimple
 
hashCode() - Method in class com.hazelcast.map.impl.MapPartitionLostEventFilter
 
hashCode() - Method in class com.hazelcast.map.impl.MapRecordKey
 
hashCode() - Method in class com.hazelcast.map.impl.operation.MapFlushWaitNotifyKey
 
hashCode() - Method in class com.hazelcast.map.impl.query.QueryEventFilter
 
hashCode() - Method in class com.hazelcast.map.impl.query.QueryResultRow
 
hashCode() - Method in class com.hazelcast.map.impl.querycache.event.BatchEventData
 
hashCode() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
hashCode() - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
hashCode() - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
 
hashCode() - Method in class com.hazelcast.map.impl.SimpleEntryView
 
hashCode() - Method in class com.hazelcast.map.impl.wan.WanMapEntryView
 
hashCode() - Method in class com.hazelcast.memory.MemorySize
 
hashCode() - Method in class com.hazelcast.multimap.impl.MultiMapEventFilter
 
hashCode() - Method in class com.hazelcast.multimap.impl.MultiMapRecord
 
hashCode() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
hashCode() - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
hashCode() - Method in class com.hazelcast.partition.PartitionAwareKey
 
hashCode() - Method in class com.hazelcast.projection.impl.MultiAttributeProjection
 
hashCode() - Method in class com.hazelcast.projection.impl.SingleAttributeProjection
 
hashCode() - Method in class com.hazelcast.query.impl.CachedQueryEntry
 
hashCode() - Method in class com.hazelcast.query.impl.CompositeValue
 
hashCode() - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
 
hashCode() - Method in class com.hazelcast.query.impl.predicates.AndPredicate
 
hashCode() - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
 
hashCode() - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
 
hashCode() - Method in class com.hazelcast.query.impl.predicates.FalsePredicate
 
hashCode() - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
 
hashCode() - Method in class com.hazelcast.query.impl.predicates.InPredicate
 
hashCode() - Method in class com.hazelcast.query.impl.predicates.InstanceOfPredicate
 
hashCode() - Method in class com.hazelcast.query.impl.predicates.LikePredicate
 
hashCode() - Method in class com.hazelcast.query.impl.predicates.NotEqualPredicate
 
hashCode() - Method in class com.hazelcast.query.impl.predicates.NotPredicate
 
hashCode() - Method in class com.hazelcast.query.impl.predicates.OrPredicate
 
hashCode() - Method in class com.hazelcast.query.impl.predicates.PartitionPredicateImpl
 
hashCode() - Method in class com.hazelcast.query.impl.predicates.RegexPredicate
 
hashCode() - Method in class com.hazelcast.query.impl.predicates.SqlPredicate
 
hashCode() - Method in class com.hazelcast.query.impl.predicates.TruePredicate
 
hashCode() - Method in class com.hazelcast.query.impl.QueryEntry
 
hashCode() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
hashCode() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
hashCode() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
hashCode() - Method in class com.hazelcast.ringbuffer.impl.RingbufferWaitNotifyKey
 
hashCode() - Method in class com.hazelcast.scheduledexecutor.impl.DelegatingScheduledFutureStripper
 
hashCode() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorWaitNotifyKey
 
hashCode() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskDescriptor
 
hashCode() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
 
hashCode() - Method in class com.hazelcast.scheduledexecutor.impl.TaskDefinition
 
hashCode() - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
hashCode() - Method in class com.hazelcast.security.permission.AllPermissions
 
hashCode() - Method in class com.hazelcast.security.permission.ClusterPermission
 
hashCode() - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
hashCode() - Method in class com.hazelcast.security.permission.InstancePermission
 
hashCode() - Method in class com.hazelcast.security.SimpleTokenCredentials
 
hashCode() - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
hashCode() - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
hashCode() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
 
hashCode() - Method in class com.hazelcast.spi.impl.eventservice.impl.TrueEventFilter
 
hashCode() - Method in class com.hazelcast.spi.impl.merge.AbstractCollectionMergingValueImpl
 
hashCode() - Method in class com.hazelcast.spi.impl.merge.AbstractMergingEntryImpl
 
hashCode() - Method in class com.hazelcast.spi.impl.merge.AbstractMergingValueImpl
 
hashCode() - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
hashCode() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
hashCode() - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
hashCode() - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
hashCode() - Method in class com.hazelcast.spi.impl.merge.RingbufferMergingValueImpl
 
hashCode() - Method in class com.hazelcast.spi.impl.operationservice.AbstractWaitNotifyKey
 
hashCode() - Method in class com.hazelcast.spi.impl.servicemanager.ServiceInfo
 
hashCode() - Method in class com.hazelcast.spi.impl.tenantcontrol.NoopTenantControl
 
hashCode() - Method in class com.hazelcast.spi.partition.PartitionMigrationEvent
 
hashCode() - Method in class com.hazelcast.splitbrainprotection.impl.ProbabilisticSplitBrainProtectionFunction
 
hashCode() - Method in class com.hazelcast.splitbrainprotection.impl.RecentlyActiveSplitBrainProtectionFunction
 
hashCode() - Method in class com.hazelcast.transaction.impl.TransactionalObjectKey
 
hashCode() - Method in class com.hazelcast.transaction.impl.xa.SerializableXID
 
hashCode() - Method in class com.hazelcast.version.MemberVersion
 
hashCode() - Method in class com.hazelcast.version.Version
 
Hashing - Class in com.hazelcast.internal.util.collection
Hashcode functions for classes in this package.
HASHMAP_DEFAULT_LOAD_FACTOR - Static variable in class com.hazelcast.internal.util.MapUtil
Default hash map load factor.
HashMapAdapter<K,V> - Class in com.hazelcast.scheduledexecutor.impl
Simple HashMap adapter class to implement DataSerializable serialization semantics to not loose hands on serialization while sending intermediate results.
HashMapAdapter() - Constructor for class com.hazelcast.scheduledexecutor.impl.HashMapAdapter
 
HashMapAdapter(int, float) - Constructor for class com.hazelcast.scheduledexecutor.impl.HashMapAdapter
 
HashMapStreamSerializer<K,V> - Class in com.hazelcast.internal.serialization.impl
The HashMap serializer Important Note: The HashMap 'loadfactor' is not serialized.
HashMapStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.HashMapStreamSerializer
 
HashSetStreamSerializer<E> - Class in com.hazelcast.internal.serialization.impl
The HashSet serializer Important Note: The HashSet 'loadfactor' is not serialized.
HashSetStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.HashSetStreamSerializer
 
HashSlotArray - Interface in com.hazelcast.internal.util.hashslot
A Flyweight object that manages the backbone array of an off-heap open-addressed hashtable.
HashSlotArray12byteKey - Interface in com.hazelcast.internal.util.hashslot
Specialization of HashSlotArray to the case where the key consists of a long and an int value and the value part is a block whose size is 4 + multiple of 8 (including zero).
HashSlotArray12byteKeyImpl - Class in com.hazelcast.internal.util.hashslot.impl
Implementation of HashSlotArray8byteKey as a restriction of HashSlotArrayBase to a case where just key1 is used.
HashSlotArray12byteKeyImpl(int, MemoryManager, int, int, float) - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArray12byteKeyImpl
 
HashSlotArray12byteKeyImpl(int, MemoryManager, int) - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArray12byteKeyImpl
 
HashSlotArray16byteKey - Interface in com.hazelcast.internal.util.hashslot
Specialization of HashSlotArray to the case where the key consists of two long values and the value part is a block whose size is a multiple of 8 (including zero).
HashSlotArray16byteKeyImpl - Class in com.hazelcast.internal.util.hashslot.impl
Implementation of HashSlotArray16byteKey.
HashSlotArray16byteKeyImpl(long, MemoryManager, MemoryAllocator, int, int, float) - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyImpl
 
HashSlotArray16byteKeyImpl(long, MemoryManager, int, int, float) - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyImpl
 
HashSlotArray16byteKeyImpl(long, MemoryManager, int) - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyImpl
 
HashSlotArray16byteKeyImpl(long, long, MemoryManager, MemoryAllocator, int, int, float) - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyImpl
 
HashSlotArray16byteKeyNoValue - Class in com.hazelcast.internal.util.hashslot.impl
Twin-key hash slot array with zero-width value.
HashSlotArray16byteKeyNoValue(long, MemoryManager, int, float) - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyNoValue
 
HashSlotArray16byteKeyNoValue(long, MemoryManager) - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyNoValue
 
HashSlotArray8byteKey - Interface in com.hazelcast.internal.util.hashslot
Specialization of HashSlotArray to the case where the key is a single long value and the value part is a block whose size is a multiple of 8 (including zero).
HashSlotArray8byteKeyImpl - Class in com.hazelcast.internal.util.hashslot.impl
Implementation of HashSlotArray8byteKey as a restriction of HashSlotArrayBase to a case where just key1 is used.
HashSlotArray8byteKeyImpl(long, MemoryManager, int, int, float) - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArray8byteKeyImpl
 
HashSlotArray8byteKeyImpl(long, MemoryManager, int) - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArray8byteKeyImpl
 
HashSlotArray8byteKeyImpl(long, long, MemoryManager, int, int, float) - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArray8byteKeyImpl
 
HashSlotArray8byteKeyNoValue - Class in com.hazelcast.internal.util.hashslot.impl
Specialization of HashSlotArray8byteKeyImpl to the case of zero-length value.
HashSlotArray8byteKeyNoValue(long, MemoryManager, int, float) - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArray8byteKeyNoValue
 
HashSlotArray8byteKeyNoValue(long, MemoryManager) - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArray8byteKeyNoValue
 
HashSlotArrayBase - Class in com.hazelcast.internal.util.hashslot.impl
Implementation of HashSlotArray, common to all its subtype implementations.
HashSlotArrayBase(long, long, MemoryManager, MemoryAllocator, int, int, int, float) - Constructor for class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
Constructs a new HashSlotArrayImpl with the given initial capacity and the load factor.
HashSlotArrayBase.Cursor - Class in com.hazelcast.internal.util.hashslot.impl
 
HashSlotArrayBase.CursorIntKey2 - Class in com.hazelcast.internal.util.hashslot.impl
 
HashSlotArrayBase.CursorLongKey2 - Class in com.hazelcast.internal.util.hashslot.impl
 
HashSlotCursor - Interface in com.hazelcast.internal.util.hashslot
Cursor over assigned slots in a HashSlotArray.
HashSlotCursor12byteKey - Interface in com.hazelcast.internal.util.hashslot
Cursor over assigned slots in a HashSlotArray12byteKey.
HashSlotCursor16byteKey - Interface in com.hazelcast.internal.util.hashslot
Cursor over assigned slots in a HashSlotArray16byteKey.
HashSlotCursor8byteKey - Interface in com.hazelcast.internal.util.hashslot
Cursor over assigned hash slots in a HashSlotArray8byteKey.
hashToIndex(int, int) - Static method in class com.hazelcast.internal.util.HashUtil
A function that calculates the index (e.g.
HashUtil - Class in com.hazelcast.internal.util
Utility methods related to hash tables.
hasIdentityConfig() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
hasInterceptor(String) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
 
hasInvalidationListener() - Method in class com.hazelcast.map.impl.MapContainer
 
hasListener(String, String) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheEventService
 
hasListener(String) - Method in class com.hazelcast.client.impl.querycache.subscriber.QueryCacheToListenerMapper
 
hasListener() - Method in class com.hazelcast.collection.impl.queue.operations.QueueOperation
 
hasListener(String, String) - Method in interface com.hazelcast.map.impl.querycache.QueryCacheEventService
Returns true if this query-cache has at least one registered user defined listener otherwise returns false.
hasListener(QueryCache) - Static method in class com.hazelcast.map.impl.querycache.subscriber.EventPublisherHelper
 
hasListener(String, String) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheEventService
 
hasListenerConfiguration() - Method in class com.hazelcast.config.AbstractCacheConfig
 
hasLock() - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
hasMember(Member) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
hasMember(Member) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
hasMember(Member) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
hasMergeablePolicy(Store) - Method in class com.hazelcast.spi.impl.merge.AbstractSplitBrainHandlerService
Checks if the given Store has a mergeable merge policy.
hasMetadata() - Method in interface com.hazelcast.cp.internal.persistence.CPMetadataStore
Returns true if this member has metadata persisted on the storage layer.
hasMetadata() - Method in class com.hazelcast.cp.internal.persistence.NopCPMetadataStore
 
hasMinimumSize() - Method in class com.hazelcast.splitbrainprotection.impl.SplitBrainProtectionImpl
 
hasMinimumSize() - Method in interface com.hazelcast.splitbrainprotection.SplitBrainProtection
Returns true if the minimum cluster size is satisfied, otherwise false.
hasNext() - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
hasNext() - Method in class com.hazelcast.client.impl.clientside.ClientDiscoveryService
 
hasNext() - Method in class com.hazelcast.client.impl.protocol.ClientMessage.ForwardFrameIterator
 
hasNext() - Method in class com.hazelcast.collection.impl.queue.QueueIterator
 
hasNext() - Method in class com.hazelcast.durableexecutor.impl.TaskRingBuffer.DurableIterator
 
hasNext() - Method in class com.hazelcast.internal.util.collection.IntIterator
 
hasNext() - Method in class com.hazelcast.internal.util.collection.LongIterator
 
hasNext() - Method in class com.hazelcast.internal.util.iterator.RestartingMemberIterator
 
hasNext() - Method in class com.hazelcast.map.impl.iterator.AbstractMapPartitionIterator
 
hasNext() - Method in class com.hazelcast.map.impl.iterator.AbstractMapQueryPartitionIterator
 
hasNext() - Method in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore.ReadOnlyRecordIterator
 
hasNext() - Method in class com.hazelcast.query.impl.getters.JsonPathCursor
 
hasNext() - Method in class com.hazelcast.ringbuffer.impl.ReadOnlyRingbufferIterator
 
hasNext() - Method in class com.hazelcast.spi.impl.merge.AbstractContainerCollector.EmptyIterator
 
hasNext() - Method in class com.hazelcast.spi.merge.RingbufferMergeDataReadOnlyIterator
 
hasNullValue() - Method in class com.hazelcast.map.impl.LazyMapEntry
Checks if this entry has null value without any deserialization.
hasOnGoingMigration() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
HasOngoingMigration - Class in com.hazelcast.internal.partition.operation
 
HasOngoingMigration() - Constructor for class com.hazelcast.internal.partition.operation.HasOngoingMigration
 
hasOnGoingMigration() - Method in interface com.hazelcast.spi.partition.IPartitionService
Checks if there are any cluster-wide migrations.
hasOnGoingMigrationLocal() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
hasOnGoingMigrationLocal() - Method in interface com.hazelcast.spi.partition.IPartitionService
Checks if there are any local migrations.
hasPartitionHash() - Method in class com.hazelcast.internal.serialization.impl.HeapData
 
hasPartitionHash() - Method in interface com.hazelcast.nio.serialization.Data
Returns true if Data has partition hash, false otherwise.
hasPartitionIndexed(int) - Method in class com.hazelcast.query.impl.IndexImpl
 
hasPartitionIndexed(int) - Method in interface com.hazelcast.query.impl.InternalIndex
Returns true if the given partition is indexed by this index, false otherwise.
hasQueryCache() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
hasQueryCache() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
hasRecordStore(String) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
 
hasReservedCapacity(UUID) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.TxnReservedCapacityCounter
 
hasReservedCapacity(UUID) - Method in class com.hazelcast.map.impl.mapstore.writebehind.TxnReservedCapacityCounterImpl
 
hasRunningCleanup(CachePartitionSegment) - Method in class com.hazelcast.cache.impl.eviction.CacheClearExpiredRecordsTask
 
hasRunningCleanup(T) - Method in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
hasRunningCleanup(PartitionContainer) - Method in class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
 
hasRunningCleanup() - Method in class com.hazelcast.map.impl.PartitionContainer
 
hasRunningCleanupOperation() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
 
hasSameUuid(UUID) - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
hasSameUuid(UUID) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecord
 
hasSpace() - Method in class com.hazelcast.spi.impl.sequence.AbstractCallIdSequence
 
hasTransformedResource() - Method in class com.hazelcast.buildutils.HazelcastManifestTransformer
 
haveAtLeastOneIndex() - Method in class com.hazelcast.query.impl.Indexes
Returns true if this indexes instance contains at least one index, false otherwise.
HAZELCAST - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
Hazelcast - Class in com.hazelcast.core
Factory for HazelcastInstance's, a node in a cluster.
HAZELCAST_ARRAY - Static variable in class com.hazelcast.internal.nio.ClassLoaderUtil
 
HAZELCAST_BASE_PACKAGE - Static variable in class com.hazelcast.internal.nio.ClassLoaderUtil
 
HAZELCAST_CLOCK_IMPL - Static variable in class com.hazelcast.internal.util.ClockProperties
The implementation of Clock.ClockImpl to use.
HAZELCAST_CLOCK_OFFSET - Static variable in class com.hazelcast.internal.util.ClockProperties
Clock offset property in milliseconds.
HAZELCAST_CLOUD_DISCOVERY_TOKEN - Static variable in class com.hazelcast.client.properties.ClientProperty
Token to use when discovering cluster via hazelcast.cloud
HAZELCAST_CONFIG_LOCATION - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
Hazelcast config location property
HAZELCAST_INSTANCE_ITSELF - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
Hazelcast instance itself property
HAZELCAST_INSTANCE_NAME - Static variable in class com.hazelcast.cache.HazelcastCachingProvider
Hazelcast instance name property
HAZELCAST_INSTANCE_NOT_ACTIVE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
HAZELCAST_INTERNAL_OVERRIDE_ENTERPRISE - Static variable in class com.hazelcast.instance.BuildInfoProvider
 
HAZELCAST_INTERNAL_OVERRIDE_VERSION - Static variable in class com.hazelcast.instance.BuildInfoProvider
 
HAZELCAST_OSGI_GROUPING_DISABLED - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
System property for disabling the behaviour that gives different cluster name to each Hazelcast bundle.
HAZELCAST_OSGI_JSR223_DISABLED - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
System property for disabling the JSR-223 script engine scan by the Hazelcast OSGI service.
HAZELCAST_OSGI_REGISTER_DISABLED - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
System property for disabling the behaviour that registers created Hazelcast instances as OSGI service.
HAZELCAST_OSGI_START - Static variable in interface com.hazelcast.osgi.HazelcastOSGiService
System property for starting a default Hazelcast instance per Hazelcast OSGI bundle.
HAZELCAST_OVERLOAD - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
HAZELCAST_SERIALIZATION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
HazelcastCache - Class in com.hazelcast.spring.cache
Sprint related Cache implementation for Hazelcast.
HazelcastCache(IMap<Object, Object>) - Constructor for class com.hazelcast.spring.cache.HazelcastCache
 
HazelcastCacheManager - Interface in com.hazelcast.cache
Contract point of Hazelcast cache manager implementations (client + server) based on CacheManager.
HazelcastCacheManager - Class in com.hazelcast.spring.cache
Sprint related HazelcastCacheManager implementation for Hazelcast.
HazelcastCacheManager() - Constructor for class com.hazelcast.spring.cache.HazelcastCacheManager
 
HazelcastCacheManager(HazelcastInstance) - Constructor for class com.hazelcast.spring.cache.HazelcastCacheManager
 
HazelcastCachingProvider - Class in com.hazelcast.cache
Hazelcast implementation of JCache CachingProvider.
HazelcastCachingProvider() - Constructor for class com.hazelcast.cache.HazelcastCachingProvider
 
HazelcastClient - Class in com.hazelcast.client
The HazelcastClient is comparable to the Hazelcast class and provides the ability the create and manage Hazelcast clients.
HazelcastClientBeanDefinitionParser - Class in com.hazelcast.spring
BeanDefinitionParser for Hazelcast Client Configuration.
HazelcastClientBeanDefinitionParser() - Constructor for class com.hazelcast.spring.HazelcastClientBeanDefinitionParser
 
HazelcastClientBeanDefinitionParser.SpringXmlBuilder - Class in com.hazelcast.spring
Client bean definition builder
HazelcastClientCacheManager - Class in com.hazelcast.client.cache.impl
CacheManager implementation for client side.
HazelcastClientCacheManager(HazelcastClientCachingProvider, HazelcastInstance, URI, ClassLoader, Properties) - Constructor for class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
 
HazelcastClientCachingProvider - Class in com.hazelcast.client.cache.impl
Hazelcast client implementation of CachingProvider.
HazelcastClientCachingProvider() - Constructor for class com.hazelcast.client.cache.impl.HazelcastClientCachingProvider
 
HazelcastClientInstanceImpl - Class in com.hazelcast.client.impl.clientside
 
HazelcastClientInstanceImpl(ClientConfig, ClientFailoverConfig, ClientConnectionManagerFactory, AddressProvider) - Constructor for class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
HazelcastClientNotActiveException - Exception in com.hazelcast.client
Thrown when Hazelcast client is not active during an invocation.
HazelcastClientNotActiveException(String) - Constructor for exception com.hazelcast.client.HazelcastClientNotActiveException
 
HazelcastClientNotActiveException(String, Throwable) - Constructor for exception com.hazelcast.client.HazelcastClientNotActiveException
 
HazelcastClientOfflineException - Exception in com.hazelcast.client
Thrown when Hazelcast client is offline during an invocation.
HazelcastClientOfflineException(String) - Constructor for exception com.hazelcast.client.HazelcastClientOfflineException
 
HazelcastClientProxy - Class in com.hazelcast.client.impl.clientside
A client-side proxy HazelcastInstance instance.
HazelcastClientProxy(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
HazelcastCloudDiscovery - Class in com.hazelcast.client.impl.spi.impl.discovery
Discovery service that discover nodes via hazelcast.cloud https://coordinator.hazelcast.cloud/cluster/discovery?token=
HazelcastCloudDiscovery(String, int) - Constructor for class com.hazelcast.client.impl.spi.impl.discovery.HazelcastCloudDiscovery
 
HazelcastConfigBeanDefinitionParser - Class in com.hazelcast.spring
BeanDefinitionParser for Hazelcast Config Configuration.
HazelcastConfigBeanDefinitionParser() - Constructor for class com.hazelcast.spring.HazelcastConfigBeanDefinitionParser
 
HazelcastException - Exception in com.hazelcast.core
Base Hazelcast exception.
HazelcastException() - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastException(String) - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastException(String, Throwable) - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastException(Throwable) - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastExpiryPolicy - Class in com.hazelcast.cache
Hazelcast provides overloads of the typical cache operations with a custom ExpiryPolicy parameter.
This class provides a custom implementation of an ExpiryPolicy to react on all three types of policies: Create Access Update
HazelcastExpiryPolicy() - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Default constructor to serialize/deserialize
HazelcastExpiryPolicy(long, long, long) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Constructs an expiry policy with provided values for creation, access and update in milliseconds.
HazelcastExpiryPolicy(long, long, long, TimeUnit) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Constructs an expiry policy with provided values for creation, access and update as well as a TimeUnit to convert those values to internally used time unites.
HazelcastExpiryPolicy(ExpiryPolicy) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Copy Constructor for an already existing ExpiryPolicy.
HazelcastExpiryPolicy(Duration, Duration, Duration) - Constructor for class com.hazelcast.cache.HazelcastExpiryPolicy
Constructs an expiry policy with provided values for creation, access and update by providing instances of the Duration class.
HazelcastFailoverClientBeanDefinitionParser - Class in com.hazelcast.spring
BeanDefinitionParser for Hazelcast Client Configuration.
HazelcastFailoverClientBeanDefinitionParser() - Constructor for class com.hazelcast.spring.HazelcastFailoverClientBeanDefinitionParser
 
hazelcastInstance - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
hazelcastInstance - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
 
HazelcastInstance - Interface in com.hazelcast.core
Hazelcast instance.
hazelcastInstance - Variable in class com.hazelcast.instance.impl.Node
 
hazelcastInstance - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
HazelcastInstanceAware - Interface in com.hazelcast.core
Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
HazelcastInstanceCacheManager - Class in com.hazelcast.cache.impl
Hazelcast ICacheManager implementation accessible via HazelcastInstance that provides access to JSR-107 (JCache) caches configured on the cluster via Hazelcast API.
HazelcastInstanceCacheManager(HazelcastInstanceImpl) - Constructor for class com.hazelcast.cache.impl.HazelcastInstanceCacheManager
 
HazelcastInstanceDefinitionParser - Class in com.hazelcast.spring
BeanDefinitionParser for Hazelcast Instance Configuration.
HazelcastInstanceDefinitionParser() - Constructor for class com.hazelcast.spring.HazelcastInstanceDefinitionParser
 
HazelcastInstanceFactory - Class in com.hazelcast.instance.impl
Central manager for all Hazelcast members of the JVM.
HazelcastInstanceImpl - Class in com.hazelcast.instance.impl
 
HazelcastInstanceImpl(String, Config, NodeContext) - Constructor for class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
HazelcastInstanceNotActiveException - Exception in com.hazelcast.core
Thrown when HazelcastInstance is not active during an invocation.
HazelcastInstanceNotActiveException() - Constructor for exception com.hazelcast.core.HazelcastInstanceNotActiveException
 
HazelcastInstanceNotActiveException(String) - Constructor for exception com.hazelcast.core.HazelcastInstanceNotActiveException
 
HazelcastInstanceProxy - Class in com.hazelcast.instance.impl
A proxy around the actual HazelcastInstanceImpl.
HazelcastInstanceProxy(HazelcastInstanceImpl) - Constructor for class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
HazelcastInternalOSGiService - Interface in com.hazelcast.osgi.impl
Contract point for internal Hazelcast services on top of OSGI.
HazelcastJsonValue - Class in com.hazelcast.core
HazelcastJsonValue is a wrapper for JSON formatted strings.
HazelcastJsonValue(String) - Constructor for class com.hazelcast.core.HazelcastJsonValue
Creates a HazelcastJsonValue from the given string.
HazelcastJsonValueSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.HazelcastJsonValueSerializer
 
HazelcastManagedContext - Class in com.hazelcast.instance.impl
 
HazelcastManagedContext(HazelcastInstanceImpl, ManagedContext) - Constructor for class com.hazelcast.instance.impl.HazelcastManagedContext
 
HazelcastManagedThread - Class in com.hazelcast.internal.util.executor
Base class for all Hazelcast threads to manage them from a single point.
HazelcastManagedThread() - Constructor for class com.hazelcast.internal.util.executor.HazelcastManagedThread
 
HazelcastManagedThread(Runnable) - Constructor for class com.hazelcast.internal.util.executor.HazelcastManagedThread
 
HazelcastManagedThread(String) - Constructor for class com.hazelcast.internal.util.executor.HazelcastManagedThread
 
HazelcastManagedThread(Runnable, String) - Constructor for class com.hazelcast.internal.util.executor.HazelcastManagedThread
 
HazelcastManifestTransformer - Class in com.hazelcast.buildutils
This transformer implementation is used to merge MANIFEST and OSGi bundle metadata in conjunction with the Maven Shade plugin when integrating multiple dependencies into one output JAR.
HazelcastManifestTransformer() - Constructor for class com.hazelcast.buildutils.HazelcastManifestTransformer
 
HazelcastMBean<T> - Class in com.hazelcast.internal.jmx
Base class for beans registered to JMX by Hazelcast.
HazelcastMBean(T, ManagementService) - Constructor for class com.hazelcast.internal.jmx.HazelcastMBean
 
HazelcastNamespaceHandler - Class in com.hazelcast.spring
Hazelcast Custom Namespace Definitions.
HazelcastNamespaceHandler() - Constructor for class com.hazelcast.spring.HazelcastNamespaceHandler
 
HazelcastOSGiInstance - Interface in com.hazelcast.osgi
Contract point for HazelcastInstance implementations based on OSGi service.
HazelcastOSGiService - Interface in com.hazelcast.osgi
Contract point for Hazelcast services on top of OSGI.
HazelcastOverloadException - Exception in com.hazelcast.core
A HazelcastException that is thrown when the system won't handle more load due to an overload.
HazelcastOverloadException(String) - Constructor for exception com.hazelcast.core.HazelcastOverloadException
 
HazelcastOverloadException(String, Throwable) - Constructor for exception com.hazelcast.core.HazelcastOverloadException
 
HazelcastProperties - Class in com.hazelcast.spi.properties
Container for configured Hazelcast properties (see HazelcastProperty).
HazelcastProperties(Config) - Constructor for class com.hazelcast.spi.properties.HazelcastProperties
Creates a container with configured Hazelcast properties.
HazelcastProperties(Properties) - Constructor for class com.hazelcast.spi.properties.HazelcastProperties
Creates a container with configured Hazelcast properties.
HazelcastProperty - Class in com.hazelcast.spi.properties
Interface for Hazelcast Member and Client properties.
HazelcastProperty(String) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Function<HazelcastProperties, ?>) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, boolean) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Integer) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Byte) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Integer, TimeUnit) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, Long, TimeUnit) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, HazelcastProperty) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, String) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, String, TimeUnit) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastProperty(String, String, TimeUnit, HazelcastProperty) - Constructor for class com.hazelcast.spi.properties.HazelcastProperty
 
HazelcastRuntimePermission - Class in com.hazelcast.security.jsm
Class which holds named Hazelcast permissions for Security Manager checks.
HazelcastRuntimePermission(String) - Constructor for class com.hazelcast.security.jsm.HazelcastRuntimePermission
Creates permission with given name.
HazelcastRuntimePermission(String, String) - Constructor for class com.hazelcast.security.jsm.HazelcastRuntimePermission
Creates permission with given name.
HazelcastSerializationException - Exception in com.hazelcast.nio.serialization
This is an exception thrown when an exception occurs while serializing/deserializing objects.
HazelcastSerializationException(String) - Constructor for exception com.hazelcast.nio.serialization.HazelcastSerializationException
 
HazelcastSerializationException(String, Throwable) - Constructor for exception com.hazelcast.nio.serialization.HazelcastSerializationException
 
HazelcastSerializationException(Throwable) - Constructor for exception com.hazelcast.nio.serialization.HazelcastSerializationException
 
HazelcastServerCacheManager - Class in com.hazelcast.cache.impl
Hazelcast CacheManager for server implementation.
HazelcastServerCacheManager(HazelcastServerCachingProvider, HazelcastInstance, URI, ClassLoader, Properties) - Constructor for class com.hazelcast.cache.impl.HazelcastServerCacheManager
 
HazelcastServerCachingProvider - Class in com.hazelcast.cache.impl
Hazelcast server implementation of CachingProvider.
HazelcastServerCachingProvider() - Constructor for class com.hazelcast.cache.impl.HazelcastServerCachingProvider
 
HazelcastTransactionManager - Class in com.hazelcast.spring.transaction
PlatformTransactionManager implementation for a single HazelcastInstance.
HazelcastTransactionManager(HazelcastInstance) - Constructor for class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
HazelcastTypeBeanDefinitionParser - Class in com.hazelcast.spring
BeanDefinitionParser for Type Configuration of Hazelcast Types like map, queue, topic etc.
HazelcastTypeBeanDefinitionParser(String) - Constructor for class com.hazelcast.spring.HazelcastTypeBeanDefinitionParser
 
HazelcastXAResource - Interface in com.hazelcast.transaction
Interface for providing Hazelcast as an XAResource
HEADER_CHUNKED - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
HEADER_CONTENT_LENGTH - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
HEADER_CONTENT_TYPE - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
HEADER_CUSTOM_PREFIX - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
HEADER_EXPECT_100 - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
HEADER_SIZE - Static variable in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
headSequence() - Method in class com.hazelcast.client.impl.proxy.ClientRingbufferProxy
 
headSequence() - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
 
headSequence() - Method in interface com.hazelcast.ringbuffer.impl.Ringbuffer
Returns the sequence of the head.
headSequence() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
 
headSequence() - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
 
headSequence() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Returns the sequence of the head.
HEALTH_MONITORING_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
HEALTH_MONITORING_LEVEL - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
HEALTH_MONITORING_THRESHOLD_CPU_PERCENTAGE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
HEALTH_MONITORING_THRESHOLD_MEMORY_PERCENTAGE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
HealthMonitor - Class in com.hazelcast.internal.diagnostics
Health monitor periodically prints logs about related internal metrics using the MetricsRegistry to provide some clues about the internal Hazelcast state.
HealthMonitor(Node) - Constructor for class com.hazelcast.internal.diagnostics.HealthMonitor
 
HealthMonitorLevel - Enum in com.hazelcast.internal.diagnostics
Health monitor can be configured with system properties.
HEAP_DATA_OVERHEAD - Static variable in class com.hazelcast.internal.serialization.impl.HeapData
 
HeapData - Class in com.hazelcast.internal.serialization.impl
A Data implementation where the content lives on the heap.
HeapData() - Constructor for class com.hazelcast.internal.serialization.impl.HeapData
 
HeapData(byte[]) - Constructor for class com.hazelcast.internal.serialization.impl.HeapData
 
HeapMemoryAccessor - Interface in com.hazelcast.internal.memory
Accessor of Java heap memory.
HeapNearCacheRecordMap<K,V extends NearCacheRecord> - Class in com.hazelcast.internal.nearcache.impl.store
SampleableNearCacheRecordMap implementation for on-heap Near Caches.
HeapNearCacheRecordMap.NearCacheEvictableSamplingEntry - Class in com.hazelcast.internal.nearcache.impl.store
 
heartbeat(RaftGroupId, long) - Method in class com.hazelcast.client.cp.internal.session.ClientProxySessionManager
 
heartbeat(RaftGroupId, long) - Method in class com.hazelcast.cp.internal.session.AbstractProxySessionManager
Commits a heartbeat for the session on the Raft group
heartbeat(RaftGroupId, long) - Method in class com.hazelcast.cp.internal.session.ProxySessionManagerService
 
heartbeat(CPGroupId, long) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
heartbeat(CPGroupId, long) - Method in interface com.hazelcast.cp.internal.session.SessionAccessor
Performs a heartbeat for the given session id in the Raft group.
heartbeat(Member, long) - Method in interface com.hazelcast.internal.cluster.fd.ClusterFailureDetector
Notifies this failure detector about received heartbeat message from a member.
heartbeat(Member, long) - Method in class com.hazelcast.internal.cluster.fd.DeadlineClusterFailureDetector
 
heartbeat(long) - Method in interface com.hazelcast.internal.cluster.fd.FailureDetector
Notifies this failure detector about received heartbeat message from the tracked member.
heartbeat(Member, long) - Method in class com.hazelcast.internal.cluster.fd.PhiAccrualClusterFailureDetector
 
heartbeat(long) - Method in class com.hazelcast.internal.cluster.fd.PhiAccrualFailureDetector
 
heartbeat(E) - Method in class com.hazelcast.internal.cluster.fd.PingFailureDetector
 
HEARTBEAT - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
HEARTBEAT_COMPLAINT - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
HEARTBEAT_FAILURE_DETECTOR_TYPE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Heartbeat failure detector type.
HEARTBEAT_INTERVAL - Static variable in class com.hazelcast.client.properties.ClientProperty
Time interval between the heartbeats sent by the client to the nodes.
HEARTBEAT_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The interval at which member heartbeat messages are sent
HEARTBEAT_PHI_FAILURE_DETECTOR_MIN_STD_DEV_MILLIS - Static variable in class com.hazelcast.internal.cluster.fd.PhiAccrualClusterFailureDetector
Minimum standard deviation to use for the normal distribution used when calculating phi.
HEARTBEAT_PHI_FAILURE_DETECTOR_SAMPLE_SIZE - Static variable in class com.hazelcast.internal.cluster.fd.PhiAccrualClusterFailureDetector
Number of samples to use for calculations.
HEARTBEAT_PHI_FAILURE_DETECTOR_THRESHOLD - Static variable in class com.hazelcast.internal.cluster.fd.PhiAccrualClusterFailureDetector
Threshold for suspicion level.
HEARTBEAT_SESSION_OP - Static variable in class com.hazelcast.cp.internal.session.RaftSessionServiceDataSerializerHook
 
HEARTBEAT_TIMEOUT - Static variable in class com.hazelcast.client.properties.ClientProperty
Client sends heartbeat messages to the members and this is the timeout for this sending operations.
HeartbeatAware - Interface in com.hazelcast.splitbrainprotection
SplitBrainProtectionFunctions which implement this interface will be notified of member heartbeats.
HeartbeatComplaintOp - Class in com.hazelcast.internal.cluster.impl.operations
 
HeartbeatComplaintOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.HeartbeatComplaintOp
 
HeartbeatComplaintOp(MembersViewMetadata, MembersViewMetadata) - Constructor for class com.hazelcast.internal.cluster.impl.operations.HeartbeatComplaintOp
 
HeartbeatManager - Class in com.hazelcast.client.impl.connection.nio
HeartbeatManager manager used by connection manager.
heartbeatMillis - Variable in class com.hazelcast.client.impl.protocol.codec.CPSessionCreateSessionCodec.ResponseParameters
TODO DOC
HeartbeatOp - Class in com.hazelcast.internal.cluster.impl.operations
A heartbeat sent from one cluster member to another.
HeartbeatOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.HeartbeatOp
 
HeartbeatOp(MembersViewMetadata, UUID, long) - Constructor for class com.hazelcast.internal.cluster.impl.operations.HeartbeatOp
 
heartbeatSession(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
HeartbeatSessionMessageTask - Class in com.hazelcast.cp.internal.session.client
Client message task for HeartbeatSessionOp
HeartbeatSessionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.session.client.HeartbeatSessionMessageTask
 
HeartbeatSessionOp - Class in com.hazelcast.cp.internal.session.operation
Pushes given session's heartbeat timeout forward.
HeartbeatSessionOp() - Constructor for class com.hazelcast.cp.internal.session.operation.HeartbeatSessionOp
 
HeartbeatSessionOp(long) - Constructor for class com.hazelcast.cp.internal.session.operation.HeartbeatSessionOp
 
HIBERNATE3_TYPE_HIBERNATE_CACHE_ENTRY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
HIBERNATE3_TYPE_HIBERNATE_CACHE_KEY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
HIBERNATE4_TYPE_HIBERNATE_CACHE_ENTRY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
HIBERNATE4_TYPE_HIBERNATE_CACHE_KEY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
HIBERNATE5_TYPE_HIBERNATE_CACHE_ENTRY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
HIBERNATE5_TYPE_HIBERNATE_CACHE_KEY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
HIBERNATE5_TYPE_HIBERNATE_NATURAL_ID_KEY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
HIBERNATE_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
HIDENSITY_CACHE_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
HIDENSITY_CACHE_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
HIGHER_HITS - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
HigherHitsMergePolicy<V,T extends MergingHits<V>> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination data structure if the source entry has more hits than the destination one.
HigherHitsMergePolicy() - Constructor for class com.hazelcast.spi.merge.HigherHitsMergePolicy
 
hintMapEvent(Address, String, EntryEventType, int, int) - Method in interface com.hazelcast.map.impl.event.MapEventPublisher
Only gives a hint which indicates that a map-wide operation has just been executed on this partition.
hintMapEvent(Address, String, EntryEventType, int, int) - Method in class com.hazelcast.map.impl.event.MapEventPublisherImpl
 
hintMapEvent(Address, String, EntryEventType, int, int) - Method in class com.hazelcast.map.impl.event.QueryCacheEventPublisher
 
HITS - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
hits - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
hits - Variable in class com.hazelcast.map.impl.record.AbstractRecord
 
hits - Variable in class com.hazelcast.map.impl.record.RecordInfo
 
HLL - Static variable in class com.hazelcast.cardinality.impl.CardinalityEstimatorDataSerializerHook
 
HLL_DENSE_ENC - Static variable in class com.hazelcast.cardinality.impl.CardinalityEstimatorDataSerializerHook
 
HLL_SPARSE_ENC - Static variable in class com.hazelcast.cardinality.impl.CardinalityEstimatorDataSerializerHook
 
holdsUnifiedSocket() - Method in class com.hazelcast.internal.networking.ServerSocketRegistry
 
HostAwareMemberGroupFactory - Class in com.hazelcast.partition.membergroup
 
HostAwareMemberGroupFactory() - Constructor for class com.hazelcast.partition.membergroup.HostAwareMemberGroupFactory
 
HOT_RESTART_BASE_DIR_DEFAULT - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
Default directory name for the Hot Restart store's home
HOT_RESTART_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
HOT_RESTART_FREE_NATIVE_MEMORY_PERCENTAGE - Static variable in class com.hazelcast.spi.properties.GroupProperty
XML and system property for setting the hot restart required free space.
HotRestartClusterDataRecoveryPolicy - Enum in com.hazelcast.config
Specifies the policy that will be respected during hot restart cluster start
hotRestartConfig - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
hot restart configuration
hotRestartConfig - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
hot restart configuration
hotRestartConfig - Variable in class com.hazelcast.config.AbstractCacheConfig
 
HotRestartConfig - Class in com.hazelcast.config
Configures the Hot Restart Persistence per Hazelcast data structure.
HotRestartConfig() - Constructor for class com.hazelcast.config.HotRestartConfig
 
HotRestartConfig(HotRestartConfig) - Constructor for class com.hazelcast.config.HotRestartConfig
 
HotRestartConfigCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
HotRestartConfigReadOnly - Class in com.hazelcast.internal.config
 
HotRestartConfigReadOnly(HotRestartConfig) - Constructor for class com.hazelcast.internal.config.HotRestartConfigReadOnly
 
HotRestartPersistenceConfig - Class in com.hazelcast.config
Configures the Hot Restart stores.
HotRestartPersistenceConfig() - Constructor for class com.hazelcast.config.HotRestartPersistenceConfig
 
HotRestartService - Interface in com.hazelcast.hotrestart
Service for interacting with Hot Restart.
HotRestartState - Interface in com.hazelcast.monitor
Hot Restart statistics to be used by MemberState implementations.
HotRestartStateImpl - Class in com.hazelcast.monitor.impl
 
HotRestartStateImpl() - Constructor for class com.hazelcast.monitor.impl.HotRestartStateImpl
 
HotRestartStateImpl(BackupTaskStatus, boolean, String) - Constructor for class com.hazelcast.monitor.impl.HotRestartStateImpl
 
HsaHeapMemoryManager - Class in com.hazelcast.internal.util.collection
Memory manager backed by long[][].
HsaHeapMemoryManager() - Constructor for class com.hazelcast.internal.util.collection.HsaHeapMemoryManager
 
HTTP_HEALTHCHECK_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
Enable or disable the RestEndpointGroup.HEALTH_CHECK group in RestApiConfig instead.
HttpCommand - Class in com.hazelcast.internal.ascii.rest
 
HttpCommand(TextCommandConstants.TextCommandType, String) - Constructor for class com.hazelcast.internal.ascii.rest.HttpCommand
 
HttpCommandProcessor<T> - Class in com.hazelcast.internal.ascii.rest
 
HttpCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
HttpDeleteCommand - Class in com.hazelcast.internal.ascii.rest
 
HttpDeleteCommand(String) - Constructor for class com.hazelcast.internal.ascii.rest.HttpDeleteCommand
 
HttpDeleteCommandParser - Class in com.hazelcast.internal.ascii.rest
 
HttpDeleteCommandParser() - Constructor for class com.hazelcast.internal.ascii.rest.HttpDeleteCommandParser
 
HttpDeleteCommandProcessor - Class in com.hazelcast.internal.ascii.rest
 
HttpDeleteCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.rest.HttpDeleteCommandProcessor
 
HttpGetCommand - Class in com.hazelcast.internal.ascii.rest
 
HttpGetCommand(String) - Constructor for class com.hazelcast.internal.ascii.rest.HttpGetCommand
 
HttpGetCommandParser - Class in com.hazelcast.internal.ascii.rest
 
HttpGetCommandParser() - Constructor for class com.hazelcast.internal.ascii.rest.HttpGetCommandParser
 
HttpGetCommandProcessor - Class in com.hazelcast.internal.ascii.rest
 
HttpGetCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.rest.HttpGetCommandProcessor
 
HttpHeadCommand - Class in com.hazelcast.internal.ascii.rest
 
HttpHeadCommand(String) - Constructor for class com.hazelcast.internal.ascii.rest.HttpHeadCommand
 
HttpHeadCommandParser - Class in com.hazelcast.internal.ascii.rest
 
HttpHeadCommandParser() - Constructor for class com.hazelcast.internal.ascii.rest.HttpHeadCommandParser
 
HttpHeadCommandProcessor - Class in com.hazelcast.internal.ascii.rest
 
HttpHeadCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.rest.HttpHeadCommandProcessor
 
HttpPostCommand - Class in com.hazelcast.internal.ascii.rest
 
HttpPostCommand(TextDecoder, String, Connection) - Constructor for class com.hazelcast.internal.ascii.rest.HttpPostCommand
 
HttpPostCommandParser - Class in com.hazelcast.internal.ascii.rest
 
HttpPostCommandParser() - Constructor for class com.hazelcast.internal.ascii.rest.HttpPostCommandParser
 
HttpPostCommandProcessor - Class in com.hazelcast.internal.ascii.rest
 
HttpPostCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.rest.HttpPostCommandProcessor
 
HttpPostCommandProcessor.ResponseType - Enum in com.hazelcast.internal.ascii.rest
 
HUNDRED - Static variable in class com.hazelcast.internal.diagnostics.OperationThreadSamplerPlugin
 
HYPER_LOG_LOG - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
HyperLogLog - Interface in com.hazelcast.cardinality.impl.hyperloglog
HyperLogLog is a redundant and highly available distributed data-structure used for cardinality estimation purposes on unique items in significantly sized data cultures.
HyperLogLogEncoder - Interface in com.hazelcast.cardinality.impl.hyperloglog.impl
 
HyperLogLogImpl - Class in com.hazelcast.cardinality.impl.hyperloglog.impl
 
HyperLogLogImpl() - Constructor for class com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogImpl
 
HyperLogLogImpl(int) - Constructor for class com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogImpl
 
HyperLogLogMergePolicy - Class in com.hazelcast.spi.merge
Only available for HyperLogLog backed CardinalityEstimator.
HyperLogLogMergePolicy() - Constructor for class com.hazelcast.spi.merge.HyperLogLogMergePolicy
 

I

IAtomicLong - Interface in com.hazelcast.cp
IAtomicLong is a redundant and highly available distributed alternative to the AtomicLong.
IAtomicReference<E> - Interface in com.hazelcast.cp
IAtomicReference is a redundant and highly available distributed alternative to the AtomicReference.
ICache<K,V> - Interface in com.hazelcast.cache
This ICache interface is the Cache extension offered by Hazelcast JCache.
In addition to the standard set of JCache methods defined in the JSR 107 specification, Hazelcast provides additional operations to support a broader range of programing styles.
ICacheDataStructureAdapter<K,V> - Class in com.hazelcast.internal.adapter
 
ICacheDataStructureAdapter(ICache<K, V>) - Constructor for class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
ICacheEvent - Interface in com.hazelcast.cache.impl.event
Cache events common contract.
ICacheInternal<K,V> - Interface in com.hazelcast.cache.impl
Internal API for ICache implementations.
ICacheManager - Interface in com.hazelcast.core
ICacheManager is the entry point to access JSR-107 (JCache) caches via HazelcastInstance interface.
ICacheRecordStore - Interface in com.hazelcast.cache.impl
ICacheRecordStore is the core contract providing internal functionality to ICache implementations on partition scope.
ICacheService - Interface in com.hazelcast.cache.impl
 
IcmpFailureDetectorConfig - Class in com.hazelcast.config
This Failure Detector may be configured in addition to one of Deadline and Phi Accual Failure Detectors.
It operates at Layer 3 of the OSI protocol, and provides much quicker and more deterministic detection of hardware
and other lower level events.
IcmpFailureDetectorConfig() - Constructor for class com.hazelcast.config.IcmpFailureDetectorConfig
 
ICMPHelper - Class in com.hazelcast.internal.util
Helper class that uses JNI to check whether the JVM process has enough permission to create raw-sockets.
ICollection<E> - Interface in com.hazelcast.collection
Concurrent, distributed, partitioned, listenable collection.
IConcurrentMap<K,V> - Interface in com.hazelcast.internal.util
A ConcurrentMap with applyIfAbsent function.
ICountDownLatch - Interface in com.hazelcast.cp
ICountDownLatch is a backed-up distributed alternative to the java.util.concurrent.CountDownLatch.
ICredentialsFactory - Interface in com.hazelcast.security
ICredentialsFactory is used to create Credentials objects to be used during node authentication before connection is accepted by the master node.
id - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveInterceptorCodec.RequestParameters
of interceptor
id() - Method in interface com.hazelcast.cp.CPGroup
Returns unique id of the CP group
id() - Method in class com.hazelcast.cp.internal.CPGroupInfo
 
id() - Method in class com.hazelcast.cp.internal.CPGroupSummary
 
id() - Method in class com.hazelcast.cp.internal.session.CPSessionInfo
 
id() - Method in interface com.hazelcast.cp.session.CPSession
Returns id of the session
id - Variable in class com.hazelcast.internal.management.dto.SlowOperationInvocationDTO
 
id - Variable in class com.hazelcast.internal.networking.nio.NioThread
 
ID - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
 
id() - Method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
 
ID_PROMOTION_OFFSET - Static variable in class com.hazelcast.collection.impl.collection.CollectionContainer
 
idBatch - Variable in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorProxy.IdBatchAndWaitTime
 
IdBatch - Class in com.hazelcast.flakeidgen.impl
Set of IDs returned from FlakeIdGenerator.
IdBatch(long, long, int) - Constructor for class com.hazelcast.flakeidgen.impl.IdBatch
Constructor
IdentifiedDataSerializable - Interface in com.hazelcast.nio.serialization
IdentifiedDataSerializable is an extension to DataSerializable to avoid reflection during de-serialization.
identity() - Static method in interface com.hazelcast.internal.util.function.FunctionEx
identity() - Static method in class com.hazelcast.projection.Projections
Returns a projection that does no transformation.
IDENTITY_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
IDENTITY_PROJECTION - Static variable in class com.hazelcast.projection.impl.ProjectionDataSerializerHook
 
IdentityConfig - Interface in com.hazelcast.config.security
This interface represents identity configuration in security realms or client security configurations.
IdentityProjection<I> - Class in com.hazelcast.projection.impl
 
idle(long) - Method in class com.hazelcast.internal.util.concurrent.BackoffIdleStrategy
Perform current idle strategy's step n.
idle(long) - Method in class com.hazelcast.internal.util.concurrent.BusySpinIdleStrategy
 
idle(long) - Method in interface com.hazelcast.internal.util.concurrent.IdleStrategy
Perform current idle strategy's step n.
idle(long) - Method in class com.hazelcast.internal.util.concurrent.NoOpIdleStrategy
 
IDLE_STRATEGY - Static variable in class com.hazelcast.spi.impl.operationservice.impl.InboundResponseHandlerSupplier
 
IdleStrategy - Interface in com.hazelcast.internal.util.concurrent
Idle strategy for use by threads when then they don't have work to do.
idOffset - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddFlakeIdGeneratorConfigCodec.RequestParameters
TODO DOC
IExecutorDelegatingFuture<V> - Class in com.hazelcast.client.impl.proxy
An Abstract DelegatingFuture that can cancel a Runnable/Callable that is executed by an IExecutorService.
IExecutorService - Interface in com.hazelcast.core
Distributed implementation of ExecutorService.
IFunction<T,R> - Interface in com.hazelcast.core
Represents a function that accepts one argument and produces a result.
ignore(Throwable) - Static method in class com.hazelcast.internal.util.EmptyStatement
Ignores the given exception.
IGNORE_ALL_EXCEPT_LOG_MEMBER_LEFT - Static variable in class com.hazelcast.internal.util.FutureUtil
Ignores all exceptions but still logs MemberLeftException per future and just tries to finish all of the given ones.
IGNORE_ALL_EXCEPTIONS - Static variable in class com.hazelcast.internal.util.FutureUtil
Ignores all exceptions
IGNORE_COMPLETION - Static variable in interface com.hazelcast.cache.impl.operation.MutableOperation
Completion ID to be ignored.
ilike(String, String) - Static method in class com.hazelcast.query.Predicates
Creates a case-insensitive like predicate that will pass items if the given pattern matches the value stored under the given item attribute in a case-insensitive manner.
ILIKE_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
ILikePredicate - Class in com.hazelcast.query.impl.predicates
Ilike Predicate
ILikePredicate() - Constructor for class com.hazelcast.query.impl.predicates.ILikePredicate
 
ILikePredicate(String, String) - Constructor for class com.hazelcast.query.impl.predicates.ILikePredicate
 
IList<E> - Interface in com.hazelcast.collection
Concurrent, distributed implementation of List.
ILLEGAL_ACCESS_ERROR - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
ILLEGAL_ACCESS_EXCEPTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
ILLEGAL_ARGUMENT - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
ILLEGAL_MONITOR_STATE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
ILLEGAL_STATE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
ILLEGAL_THREAD_STATE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
ILogger - Interface in com.hazelcast.logging
The Hazelcast logging interface.
IMap<K,V> - Interface in com.hazelcast.map
Concurrent, distributed, observable and queryable map.
IMapDataStructureAdapter<K,V> - Class in com.hazelcast.internal.adapter
 
IMapDataStructureAdapter(IMap<K, V>) - Constructor for class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
IMapEvent - Interface in com.hazelcast.map
Map events common contract.
ImmutableInflatableSet<T> - Class in com.hazelcast.internal.util.collection
An immutable InflatableSet.
ImmutableInflatableSet.ImmutableSetBuilder<T> - Class in com.hazelcast.internal.util.collection
ImmutableMultiResult<T> - Class in com.hazelcast.query.impl.getters
Immutable version of the MultiResult.
ImmutableMultiResult(MultiResult<T>) - Constructor for class com.hazelcast.query.impl.getters.ImmutableMultiResult
 
ImmutablePartitionIdSet - Class in com.hazelcast.internal.util.collection
An immutable PartitionIdSet.
ImmutablePartitionIdSet(int, Collection<Integer>) - Constructor for class com.hazelcast.internal.util.collection.ImmutablePartitionIdSet
 
immutablePartitionIdSet(int, Collection<Integer>) - Static method in class com.hazelcast.internal.util.SetUtil
 
implementation - Variable in class com.hazelcast.config.AbstractWanPublisherConfig
 
implementation - Variable in class com.hazelcast.config.ListenerConfig
 
implementation - Variable in class com.hazelcast.config.PredicateConfig
 
implementation - Variable in class com.hazelcast.config.SecurityInterceptorConfig
 
implementsInterfaceWithSameName(Class<?>, Class<?>) - Static method in class com.hazelcast.internal.nio.ClassLoaderUtil
Check whether given class implements an interface with the same name.
implies(Permission) - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
implies(Permission) - Method in class com.hazelcast.security.permission.AllPermissions
 
implies(Permission) - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
implies(Permission) - Method in class com.hazelcast.security.permission.ConfigPermission
 
implies(Permission) - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
implies(Permission) - Method in class com.hazelcast.security.permission.InstancePermission
 
implies(Permission) - Method in class com.hazelcast.security.permission.TransactionPermission
 
importDocuments(YamlNode) - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
Imports external YAML documents into the provided main YAML document.
in(Comparable...) - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
in(Comparable...) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
in(String, Comparable...) - Static method in class com.hazelcast.query.Predicates
Creates a in predicate that will pass items if the value stored under the given item attribute is a member of the given values set.
IN_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
InboundHandler<S,D> - Class in com.hazelcast.internal.networking
The InboundHandler provides control when data is received and needs to be processed.
InboundHandler() - Constructor for class com.hazelcast.internal.networking.InboundHandler
 
inboundHandlers - Variable in class com.hazelcast.internal.nio.tcp.SingleProtocolDecoder
 
InboundHandlerWithCounters<S,D> - Class in com.hazelcast.internal.networking.nio
Trigger for the ChannelReader to inject the appropriate counters.
InboundHandlerWithCounters() - Constructor for class com.hazelcast.internal.networking.nio.InboundHandlerWithCounters
 
inboundPipeline() - Method in interface com.hazelcast.internal.networking.Channel
Returns the InboundPipeline that belongs to this Channel.
InboundPipeline - Interface in com.hazelcast.internal.networking
The InboundPipeline is pipeline responsible for inbound traffic.
inboundPipeline() - Method in class com.hazelcast.internal.networking.nio.NioChannel
 
InboundResponseHandler - Class in com.hazelcast.spi.impl.operationservice.impl
Responsible for handling responses for invocations.
InboundResponseHandlerSupplier - Class in com.hazelcast.spi.impl.operationservice.impl
A Supplier responsible for providing a Consumer that processes inbound responses.
inc() - Method in interface com.hazelcast.internal.util.counters.Counter
Increments the counter by one.
inc(long) - Method in interface com.hazelcast.internal.util.counters.Counter
Increments (or decrements) the counter by the given amount.
inc() - Method in class com.hazelcast.internal.util.counters.MwCounter
 
inc(long) - Method in class com.hazelcast.internal.util.counters.MwCounter
 
inc(T) - Method in class com.hazelcast.internal.util.ItemCounter
Increases the count by on for the given item.
INCLUDE_EPOCH_TIME - Static variable in class com.hazelcast.internal.diagnostics.Diagnostics
Configures if the epoch time should be included in the 'top' section.
INCLUDE_NAME - Static variable in class com.hazelcast.internal.diagnostics.OperationThreadSamplerPlugin
If the name the data-structure the operation operates on should be included.
includeValue - Variable in class com.hazelcast.client.impl.protocol.codec.ListAddListenerCodec.RequestParameters
Set to true if you want the event to contain the value.
includeValue - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerCodec.RequestParameters
true if EntryEvent should contain the value.
includeValue - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyCodec.RequestParameters
true if EntryEvent should contain the value.
includeValue - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyWithPredicateCodec.RequestParameters
true if EntryEvent should contain the value.
includeValue - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerWithPredicateCodec.RequestParameters
true if EntryEvent should contain the value.
includeValue - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerCodec.RequestParameters
True if EntryEvent should contain the value,false otherwise
includeValue - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerToKeyCodec.RequestParameters
True if EntryEvent should contain the value,false otherwise
includeValue - Variable in class com.hazelcast.client.impl.protocol.codec.QueueAddListenerCodec.RequestParameters
true if the updated item should be passed to the item listener, false otherwise.
includeValue - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddNearCacheEntryListenerCodec.RequestParameters
True if EntryEvent should contain the value,false otherwise
includeValue - Variable in class com.hazelcast.client.impl.protocol.codec.SetAddListenerCodec.RequestParameters
if set to true, the event shall also include the value.
includeValue - Variable in class com.hazelcast.map.impl.EntryEventFilter
 
increase(int) - Method in class com.hazelcast.internal.jmx.SemaphoreMBean
 
increaseCacheEntryListenerCount() - Method in class com.hazelcast.cache.impl.CacheContext
 
increaseCacheEvictions() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Increases the counter by `1`.
increaseCacheEvictions(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Increases the counter by the number specified.
increaseCacheExpiries() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Increases the counter by `1`.
increaseCacheExpiries(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Increases the counter by the number specified.
increaseCacheHits() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Increases the counter by `1`.
increaseCacheHits(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Increases the counter by the number specified.
increaseCacheMisses() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Increases the counter by `1`.
increaseCacheMisses(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Increases the counter by the number specified.
increaseCachePuts() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Increases the counter by `1`.
increaseCachePuts(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Increases the counter by the number specified.
increaseCacheRemovals() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Increases the counter by `1`.
increaseCacheRemovals(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Increases the counter by the number specified.
increaseEntryCount() - Method in class com.hazelcast.cache.impl.CacheContext
 
increaseEntryCount(long) - Method in class com.hazelcast.cache.impl.CacheContext
 
increaseHits() - Method in class com.hazelcast.monitor.impl.LocalRecordStoreStatsImpl
 
increaseHits(long) - Method in class com.hazelcast.monitor.impl.LocalRecordStoreStatsImpl
 
increaseHits() - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Increases the number of hits of the locally owned entries of this partition.
increaseHits(long) - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Increases the number of hits of the locally owned entries of this partition.
increaseInvalidationListenerCount() - Method in class com.hazelcast.cache.impl.CacheContext
 
increaseInvalidationListenerCount() - Method in class com.hazelcast.map.impl.MapContainer
 
increasePermits(int) - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionAwareSemaphoreProxy
 
increasePermits(int) - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionlessSemaphoreProxy
 
increasePermits(int) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionAwareSemaphoreProxy
 
increasePermits(int) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionlessSemaphoreProxy
 
increasePermits(int) - Method in interface com.hazelcast.cp.ISemaphore
Increases the number of available permits by the indicated amount.
increment - Variable in class com.hazelcast.client.impl.protocol.codec.FlakeIdGeneratorNewIdBatchCodec.ResponseParameters
TODO DOC
INCREMENT - Static variable in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorProxy
The difference between two IDs from a sequence on single member
increment() - Method in class com.hazelcast.flakeidgen.impl.IdBatch
Returns increment from IdBatch.base() for the next ID in the set.
increment(UUID, boolean) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.TxnReservedCapacityCounter
Increments capacity count for a transaction.
increment(UUID, boolean) - Method in class com.hazelcast.map.impl.mapstore.writebehind.TxnReservedCapacityCounterImpl
Increments 2 counters for supplied txnId.
incrementAccessHit() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
incrementAccessHit() - Method in interface com.hazelcast.cache.impl.record.CacheRecord
Increases the access hit count of this Evictable as 1.
incrementAccessHit() - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
incrementAccessHit() - Method in interface com.hazelcast.internal.nearcache.NearCacheRecord
Increases the access hit count of this Evictable by 1.
incrementAccessHit() - Method in interface com.hazelcast.map.impl.querycache.subscriber.record.QueryCacheRecord
Increases the access hit count of this Evictable as 1.
incrementAndGet() - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
incrementAndGet() - Method in class com.hazelcast.client.impl.proxy.ClientPNCounterProxy
 
incrementAndGet() - Method in interface com.hazelcast.cp.IAtomicLong
Atomically increments the current value by one.
incrementAndGet() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
incrementAndGet() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Increments by one the current value.
incrementAndGet() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterProxy
 
incrementAndGet() - Method in class com.hazelcast.internal.jmx.AtomicLongMBean
 
incrementAndGet() - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
incrementAndGet() - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
incrementAndGetAsync() - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
incrementAndGetAsync() - Method in interface com.hazelcast.cp.IAtomicLong
Atomically increments the current value by one.
incrementAndGetAsync() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
incrementAndGetAsync() - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
incrementAndGetAsync() - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
incrementBackupEntryCount(long) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
 
incrementBackupEntryMemoryCost(long) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
 
IncrementCommand - Class in com.hazelcast.internal.ascii.memcache
 
IncrementCommand(TextCommandConstants.TextCommandType, String, int, boolean) - Constructor for class com.hazelcast.internal.ascii.memcache.IncrementCommand
 
IncrementCommandParser - Class in com.hazelcast.internal.ascii.memcache
 
IncrementCommandParser(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.internal.ascii.memcache.IncrementCommandParser
 
IncrementCommandProcessor - Class in com.hazelcast.internal.ascii.memcache
 
IncrementCommandProcessor(TextCommandServiceImpl) - Constructor for class com.hazelcast.internal.ascii.memcache.IncrementCommandProcessor
 
incrementDecrementOperationCount() - Method in class com.hazelcast.monitor.impl.LocalPNCounterStatsImpl
Increments the number of subtract (including decrement) operations on this PN counter.
incrementDecrHitCount() - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
incrementDecrHitCount() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
incrementDecrMissCount() - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
incrementDecrMissCount() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
incrementDeleteHitCount(int) - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
incrementDeleteHitCount(int) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
incrementDeleteMissCount() - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
incrementDeleteMissCount() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
incrementDirtyEntryCount(long) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
 
incrementDropped(String) - Method in class com.hazelcast.wan.DistributedServiceWanEventCounters
Increment the number of dropped events for the distributedObjectName.
incrementEmptyPolls() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
incrementEventCount(DistributedServiceWanEventCounters) - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
 
incrementEventCount(DistributedServiceWanEventCounters) - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
 
incrementEventCount(DistributedServiceWanEventCounters) - Method in interface com.hazelcast.wan.WanReplicationEvent
Increments the count for the related event in the counters
incrementEvictions() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
incrementExpirations() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
incrementGetHitCount() - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
incrementGetHitCount() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
incrementGetLatencyNanos(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
incrementGetLatencyNanos(long, long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
incrementGetMissCount() - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
incrementGetMissCount() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
incrementGets(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
incrementHeapCost(long) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
 
incrementHit() - Method in class com.hazelcast.multimap.impl.MultiMapValue
 
incrementHits(long) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
 
incrementHits() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
incrementIncHitCount() - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
incrementIncHitCount() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
incrementIncMissCount() - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
incrementIncMissCount() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
incrementIncrementOperationCount() - Method in class com.hazelcast.monitor.impl.LocalPNCounterStatsImpl
Increments the number of add (including increment) operations on this PN counter.
incrementIndexedQueryCount() - Method in class com.hazelcast.monitor.impl.GlobalIndexesStats
 
incrementIndexedQueryCount() - Method in interface com.hazelcast.monitor.impl.IndexesStats
Increments the number of indexed queries performed on the indexes.
incrementIndexedQueryCount() - Method in class com.hazelcast.monitor.impl.PartitionIndexesStats
 
incrementInvalidationRequests() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
incrementInvalidations() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
incrementInvalidations(long) - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
incrementLockedEntryCount(long) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
 
incrementMerkleTreesCost(long) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
 
incrementMisses() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
incrementOffers() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
incrementOperationStats(long, LocalMapStatsImpl, String, Operation) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
incrementOtherOperations() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
incrementOtherOperations() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
incrementOtherOperations() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
incrementOtherOperationsCount(MapService, String) - Static method in class com.hazelcast.map.impl.LocalMapStatsUtil
Increments other operations count statistic in local map statistics.
incrementOwnedEntryCount(long) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
 
incrementOwnedEntryCount() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
incrementOwnedEntryMemoryCost(long) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
 
incrementOwnedEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
incrementPartitionReplicaVersions(int, ServiceNamespace, int) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
 
incrementPartitionReplicaVersions(int, ServiceNamespace, int) - Method in interface com.hazelcast.internal.partition.PartitionReplicaVersionManager
Increments replica versions for given partition and namespace by the number of backup count.
incrementPolls() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
incrementPublishedEventCount(long) - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
incrementPublishes() - Method in class com.hazelcast.monitor.impl.LocalTopicStatsImpl
Increment the number of locally published messages.
incrementPublishes(String) - Method in class com.hazelcast.topic.impl.TopicService
Increments the number of published messages on the ITopic with the name topicName.
incrementPutLatencyNanos(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
incrementPutLatencyNanos(long, long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
incrementPuts(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
incrementQueryCount() - Method in class com.hazelcast.monitor.impl.GlobalIndexesStats
 
incrementQueryCount() - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
incrementQueryCount() - Method in interface com.hazelcast.monitor.impl.IndexesStats
Increments the number of queries performed on the indexes.
incrementQueryCount() - Method in class com.hazelcast.monitor.impl.PartitionIndexesStats
 
incrementQueryCount() - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
incrementQueryCount() - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Increments the query count for the index.
incrementReceivedEvents() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
incrementReceivedEvents() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
incrementReceivedEvents() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
incrementReceivedMessages(String) - Method in class com.hazelcast.topic.impl.TopicService
Increments the number of received messages on the ITopic with the name topicName.
incrementReceives() - Method in class com.hazelcast.monitor.impl.LocalTopicStatsImpl
Increment the number of locally received messages.
incrementRejectedOffers() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
incrementRemove(String) - Method in class com.hazelcast.wan.DistributedServiceWanEventCounters
Increment the number of remove events for the distributedObjectName.
incrementRemoveLatencyNanos(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
incrementRemoves(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
incrementSetCount() - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
incrementSetCount() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
incrementSetLatencyNanos(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
incrementSync(String) - Method in class com.hazelcast.wan.DistributedServiceWanEventCounters
Increment the number of sync events for the distributedObjectName.
incrementSync(String, int) - Method in class com.hazelcast.wan.DistributedServiceWanEventCounters
Increment the number of sync events for the distributedObjectName by count.
incrementTouchCount() - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
incrementTouchCount() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
incrementUpdate(String) - Method in class com.hazelcast.wan.DistributedServiceWanEventCounters
Increment the number of update events for the distributedObjectName.
incrementVersion() - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
 
indentWithSpaces(int) - Static method in class com.hazelcast.internal.json.PrettyPrint
Print every value on a separate line.
indentWithTabs() - Static method in class com.hazelcast.internal.json.PrettyPrint
Do not break lines, but still insert whitespace between values.
INDETERMINATE_OPERATION_STATE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
IndeterminateOperationState - Interface in com.hazelcast.core
A marker interface for exceptions to denote that execution status of an invocation is not known
IndeterminateOperationStateAware - Interface in com.hazelcast.cp.internal
When a RaftOp is replicated to the leader of a Raft group, but the leader fails before it sends any response, the caller has no idea about the status of its operation.
IndeterminateOperationStateException - Exception in com.hazelcast.core
IndeterminateOperationStateException is thrown when result of an invocation becomes indecisive.
IndeterminateOperationStateException() - Constructor for exception com.hazelcast.core.IndeterminateOperationStateException
 
IndeterminateOperationStateException(String) - Constructor for exception com.hazelcast.core.IndeterminateOperationStateException
 
IndeterminateOperationStateException(String, Throwable) - Constructor for exception com.hazelcast.core.IndeterminateOperationStateException
 
index - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
index - Variable in class com.hazelcast.client.impl.protocol.codec.ListAddAllWithIndexCodec.RequestParameters
index at which to insert the first element from the specified collection.
index - Variable in class com.hazelcast.client.impl.protocol.codec.ListAddWithIndexCodec.RequestParameters
index at which the specified element is to be inserted
index - Variable in class com.hazelcast.client.impl.protocol.codec.ListGetCodec.RequestParameters
Index of the element to return
index - Variable in class com.hazelcast.client.impl.protocol.codec.ListListIteratorCodec.RequestParameters
index of the first element to be returned from the list iterator next
index - Variable in class com.hazelcast.client.impl.protocol.codec.ListRemoveWithIndexCodec.RequestParameters
The index of the element to be removed
index - Variable in class com.hazelcast.client.impl.protocol.codec.ListSetCodec.RequestParameters
Index of the element to replace
index() - Method in class com.hazelcast.cp.internal.raft.impl.log.LogEntry
 
index() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftGroupMembers
Returns the position of the membership change that leads to formation of this group.
index - Variable in class com.hazelcast.map.impl.iterator.AbstractMapPartitionIterator
 
index - Variable in class com.hazelcast.map.impl.iterator.AbstractMapQueryPartitionIterator
 
Index - Interface in com.hazelcast.query.impl
Represents an index built on top of the attribute of the map entries.
Index.OperationSource - Enum in com.hazelcast.query.impl
Identifies an original source of an index operation.
INDEX_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
INDEX_COPY_BEHAVIOR - Static variable in class com.hazelcast.spi.properties.GroupProperty
Type of Query Index result copying behavior.
INDEX_OF - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
INDEX_OUT_OF_BOUNDS - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
IndexAwarePredicate<K,V> - Interface in com.hazelcast.query.impl.predicates
Extends the Predicate interface with the ability to support indexes.
indexConfig - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddIndexCodec.RequestParameters
Index configuration.
IndexConfig - Class in com.hazelcast.config
Configuration of an index.
IndexConfig() - Constructor for class com.hazelcast.config.IndexConfig
 
IndexConfig(IndexType) - Constructor for class com.hazelcast.config.IndexConfig
Creates an index configuration of the given type.
IndexConfig(IndexType, String...) - Constructor for class com.hazelcast.config.IndexConfig
Creates an index configuration of the given type with provided attributes.
IndexConfig(IndexConfig) - Constructor for class com.hazelcast.config.IndexConfig
 
IndexConfigCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
IndexConfigReadOnly - Class in com.hazelcast.internal.config
Read-only counterpart of IndexConfig class.
IndexConfigReadOnly(IndexConfig) - Constructor for class com.hazelcast.internal.config.IndexConfigReadOnly
 
indexConfigs - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
index configurations
IndexCopyBehavior - Enum in com.hazelcast.query.impl
Defines the behavior for index copying on index read/write.
Indexes - Class in com.hazelcast.query.impl
Contains all indexes for a data-structure, e.g.
indexes - Variable in class com.hazelcast.query.impl.QueryContext
 
Indexes.Builder - Class in com.hazelcast.query.impl
Builder which is used to create a new Indexes object.
IndexesStats - Interface in com.hazelcast.monitor.impl
Provides internal statistics for Indexes.
IndexHeapMemoryCostUtil - Class in com.hazelcast.query.impl
Provides utilities useful for on-heap memory cost estimation.
IndexImpl - Class in com.hazelcast.query.impl
Provides implementation of on-heap indexes.
IndexImpl(IndexConfig, InternalSerializationService, Extractors, IndexCopyBehavior, PerIndexStats) - Constructor for class com.hazelcast.query.impl.IndexImpl
 
indexOf(Object) - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
indexOf(boolean, Data) - Method in class com.hazelcast.collection.impl.list.ListContainer
 
indexOf(Object) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
 
indexOf(String, char, int) - Static method in class com.hazelcast.internal.util.StringUtil
Like a String.indexOf but without MIN_SUPPLEMENTARY_CODE_POINT handling
indexOf(String, char) - Static method in class com.hazelcast.internal.util.StringUtil
Like a String.indexOf but without MIN_SUPPLEMENTARY_CODE_POINT handling
indexOfFirstTailEntry() - Method in class com.hazelcast.cp.internal.raft.impl.persistence.LogFileStructure
 
IndexOperationStats - Interface in com.hazelcast.monitor.impl
Provides per-operation statistics tracking for indexes.
indexProvider(IndexProvider) - Method in class com.hazelcast.query.impl.Indexes.Builder
 
IndexProvider - Interface in com.hazelcast.query.impl
Provides storage-specific indexes to Indexes.
indexStore - Variable in class com.hazelcast.query.impl.AbstractIndex
 
IndexStore - Interface in com.hazelcast.query.impl
Defines a contract for index stores, so different index stores may be used interchangeably with the same Index implementation.
IndexType - Enum in com.hazelcast.config
Type of the index.
IndexUtils - Class in com.hazelcast.query.impl
Utility methods for indexes.
InflatableSet<T> - Class in com.hazelcast.internal.util.collection
Provides fast Set implementation for cases where items are known to not contain duplicates.
InflatableSet.Builder<T> - Class in com.hazelcast.internal.util.collection
Builder for InflatableSet.
info(String) - Method in class com.hazelcast.logging.AbstractLogger
 
info(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
info(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
info(String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at the Level.INFO level.
info(Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a throwable at the Level.INFO level.
info(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the Level.INFO level.
init() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
init(NodeEngine, Properties) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
init() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
 
init() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Initializes record store.
init(NodeEngine, Properties) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorService
 
init(int, SparseHyperLogLogEncoder.VariableLengthDiffArray) - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.SparseHyperLogLogEncoder
 
init(ClientContext) - Method in class com.hazelcast.client.cp.internal.CPSubsystemImpl
 
init(ClientContext) - Method in class com.hazelcast.client.cp.internal.datastructures.proxy.ClientRaftProxyFactory
 
init(int) - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionAwareSemaphoreProxy
 
init(int) - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionlessSemaphoreProxy
 
init(NodeEngine, Properties) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
init(ClientContext) - Method in class com.hazelcast.client.impl.connection.ClientConnectionStrategy
Initialize this strategy with client context and config
init(ClientContext) - Method in class com.hazelcast.client.impl.connection.nio.DefaultClientConnectionStrategy
 
init(ClientConfig, ClientContext) - Method in class com.hazelcast.client.impl.spi.ProxyManager
 
init(Cluster, ClientConfig) - Method in interface com.hazelcast.client.LoadBalancer
Initializes the LoadBalancer.
init(Cluster, ClientConfig) - Method in class com.hazelcast.client.util.AbstractLoadBalancer
 
init(InitialMembershipEvent) - Method in class com.hazelcast.client.util.AbstractLoadBalancer
 
init(Cluster, ClientConfig) - Method in class com.hazelcast.client.util.StaticLB
 
init(InitialMembershipEvent) - Method in interface com.hazelcast.cluster.InitialMembershipListener
Called when this listener is registered.
init(NodeEngine) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
init(NodeEngine, Properties) - Method in class com.hazelcast.collection.impl.collection.CollectionService
 
init(boolean) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Initializes the item queue with items from the queue store if the store is enabled and if item queue is not being initialized as a part of a backup operation.
init(NodeEngine, Properties) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
init(Properties) - Method in class com.hazelcast.config.replacer.AbstractPbeReplacer
 
init(Properties) - Method in class com.hazelcast.config.replacer.EncryptionReplacer
 
init(Properties) - Method in class com.hazelcast.config.replacer.PropertyReplacer
 
init(Properties) - Method in interface com.hazelcast.config.replacer.spi.ConfigReplacer
Initialization method called before first usage of the config replacer.
init(int) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionAwareSemaphoreProxy
 
init(int) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionlessSemaphoreProxy
 
init(NodeEngine, Properties) - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueService
 
init(NodeEngine, Properties) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
init() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Initializes the Raft state by initializing the state store and persisting the initial member list
init(NodeEngine, Properties) - Method in class com.hazelcast.cp.internal.RaftService
 
init(NodeEngine, Properties) - Method in class com.hazelcast.cp.internal.session.ProxySessionManagerService
 
init(NodeEngine, Properties) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
init(int) - Method in interface com.hazelcast.cp.ISemaphore
Tries to initialize this ISemaphore instance with the given permit count
init(NodeEngine, Properties) - Method in class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
 
init(NodeEngine, Properties) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
 
init(NodeEngine, Properties) - Method in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorService
 
init(TextDecoder, long) - Method in class com.hazelcast.internal.ascii.AbstractTextCommand
 
init(TextDecoder, long) - Method in interface com.hazelcast.internal.ascii.TextCommand
 
init(NodeEngine, Properties) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
init(NodeEngine, Properties) - Method in class com.hazelcast.internal.crdt.CRDTReplicationMigrationService
 
init(NodeEngine, Properties) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterService
 
init(PrintWriter) - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
init(NodeEngine, Properties) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
init(NodeEngine, Properties) - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
init(NodeEngine, Properties) - Method in class com.hazelcast.internal.longregister.LongRegisterService
 
init(MCMutualAuthConfig) - Method in interface com.hazelcast.internal.management.ManagementCenterConnectionFactory
 
init() - Method in class com.hazelcast.internal.management.TimedMemberStateFactory
 
init(NodeEngine, Properties) - Method in class com.hazelcast.internal.metrics.impl.MetricsService
 
init(RepairingHandler) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationMetaDataFetcher
 
init(NioInboundPipeline, NioOutboundPipeline) - Method in class com.hazelcast.internal.networking.nio.NioChannel
 
init(byte[], int) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
init() - Method in class com.hazelcast.internal.nio.tcp.DefaultChannelInitializerProvider
 
init(NodeEngine, Properties) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
init(NodeEngine, Properties) - Method in interface com.hazelcast.internal.services.ManagedService
Initializes this service.
init(NodeEngine, Properties) - Method in class com.hazelcast.internal.usercodedeployment.UserCodeDeploymentService
 
init(NodeEngine, Properties) - Method in class com.hazelcast.map.impl.MapManagedService
 
init(NodeEngine, Properties) - Method in class com.hazelcast.map.impl.MapService
 
init(HazelcastInstance, Properties, String) - Method in class com.hazelcast.map.impl.MapStoreWrapper
 
init(Data, Object, Object, Data, EntryEventType) - Method in class com.hazelcast.map.impl.operation.EntryOperator
 
init() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Initialize the recordStore after creation
init(HazelcastInstance, Properties, String) - Method in interface com.hazelcast.map.MapLoaderLifecycleSupport
Initializes this MapLoader implementation.
init(NodeEngine, Properties) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
init(Properties) - Method in interface com.hazelcast.nio.SocketInterceptor
Initializes socket interceptor with properties which is set by Config.setProperty(String, String)
init(Properties) - Method in class com.hazelcast.nio.ssl.BasicSSLContextFactory
 
init(Properties) - Method in interface com.hazelcast.nio.ssl.SSLContextFactory
Initializes this class with config from SSLConfig
init(InternalSerializationService, Data, Object, Extractors) - Method in class com.hazelcast.query.impl.CachedQueryEntry
 
init(InternalSerializationService, Data, Object, Extractors) - Method in class com.hazelcast.query.impl.QueryEntry
It may be useful to use this init method in some cases that same instance of this class can be used instead of creating a new one for every iteration when scanning large data sets, for example:
init(NodeEngine, Properties) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
init(RingbufferConfig, NodeEngine) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
Initializes the ring buffer with references to other services, the ringbuffer store and the config.
init(NodeEngine, Properties) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
init(NodeEngine, Properties) - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
init(Properties) - Method in interface com.hazelcast.security.ICredentialsFactory
This method is (only) called if the factory instance is newly created from a class name provided in CredentialsFactoryConfig.
init(NodeEngineImpl, Set<Operation>) - Method in class com.hazelcast.spi.impl.operationservice.Offload
Initializes the Offload.
init() - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
 
init() - Method in class com.hazelcast.spring.HazelcastNamespaceHandler
 
init(NodeEngine, Properties) - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicService
 
init(NodeEngine, Properties) - Method in class com.hazelcast.topic.impl.TopicService
 
init(NodeEngine, Properties) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
init(NodeEngine, Properties) - Method in class com.hazelcast.transaction.impl.xa.XAService
 
init(WanReplicationConfig, AbstractWanPublisherConfig) - Method in interface com.hazelcast.wan.WanReplicationPublisher
Initializes the publisher.
INIT_CLUSTER_VERSION - Static variable in class com.hazelcast.spi.properties.GroupProperty
Override cluster version to use while node is not yet member of a cluster.
INIT_METADATA_RAFT_GROUP_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
INIT_SEMAPHORE_OP - Static variable in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreDataSerializerHook
 
initChannel(Channel) - Method in class com.hazelcast.client.impl.connection.nio.ClientPlainChannelInitializer
 
initChannel(Channel) - Method in interface com.hazelcast.internal.networking.ChannelInitializer
Initializes the channel.
initChannel(Channel) - Method in class com.hazelcast.internal.nio.ascii.TextChannelInitializer
 
initChannel(Channel) - Method in class com.hazelcast.internal.nio.tcp.ClientChannelInitializer
 
initChannel(Channel) - Method in class com.hazelcast.internal.nio.tcp.MemberChannelInitializer
 
initChannel(Channel) - Method in class com.hazelcast.internal.nio.tcp.UnifiedChannelInitializer
 
initDataSerializableInputAndSkipTheHeader(Data) - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1
Init the ObjectDataInput for the given Data skipping the serialization header-bytes and navigating to the position from where the readData() starts reading the object fields.
initDefaultMaxSizeForOnHeapMaps(NearCacheConfig) - Static method in class com.hazelcast.config.NearCacheConfigAccessor
 
initDstBuffer() - Method in class com.hazelcast.internal.networking.OutboundHandler
Initializes the dst ByteBuffer with the value for ChannelOption.SO_SNDBUF.
initDstBuffer(int) - Method in class com.hazelcast.internal.networking.OutboundHandler
Initializes the dst ByteBuffer with the configured size.
initDstBuffer(int, byte[]) - Method in class com.hazelcast.internal.networking.OutboundHandler
Initializes the dst ByteBuffer with the configured size.
initEvictor() - Method in class com.hazelcast.map.impl.MapContainer
 
initExpirationIterator() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
initFactories() - Method in class com.hazelcast.client.impl.protocol.DefaultMessageTaskFactoryProvider
 
INITIAL_BACKOFF_MS - Static variable in class com.hazelcast.topic.impl.reliable.ReliableTopicProxy
 
INITIAL_MEMORY_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
Initial memory size in megabytes
INITIAL_METADATA_GROUP_ID - Static variable in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
INITIAL_MIN_CLUSTER_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
INITIAL_WAIT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
initialDelayInMillis - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToAddressCodec.RequestParameters
initial delay in milliseconds
initialDelayInMillis - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToPartitionCodec.RequestParameters
initial delay in milliseconds
initialize() - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
initialize(Object) - Method in interface com.hazelcast.core.ManagedContext
Initialize the given object instance.
initialize(Object) - Method in class com.hazelcast.instance.impl.HazelcastManagedContext
 
initialize() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
initialize() - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
initialize() - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
initialize() - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
initialize() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
initialize() - Method in interface com.hazelcast.spi.impl.InitializingObject
 
initialize(Object) - Method in class com.hazelcast.spring.context.SpringManagedContext
 
initialize() - Method in class com.hazelcast.topic.impl.TopicProxySupport
 
initializeContext(ManagedContext) - Method in class com.hazelcast.scheduledexecutor.impl.NamedTaskDecorator
 
initializeDistributedObject(String, String) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
 
initializeDistributedObject(String, String) - Method in interface com.hazelcast.spi.impl.proxyservice.ProxyService
 
InitializeDistributedObjectOperation - Class in com.hazelcast.spi.impl.proxyservice.impl.operations
 
InitializeDistributedObjectOperation() - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.operations.InitializeDistributedObjectOperation
 
InitializeDistributedObjectOperation(String, String) - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.operations.InitializeDistributedObjectOperation
 
initializeListeners(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
InitializingObject - Interface in com.hazelcast.spi.impl
Can be implemented by DistributedObject (proxies) to indicate that they want to be initialized.
initialMemberCount() - Method in class com.hazelcast.cp.internal.CPGroupInfo
 
initialMembers() - Method in class com.hazelcast.cp.internal.CPGroupInfo
 
initialMembers() - Method in class com.hazelcast.cp.internal.CPGroupSummary
 
initialMembers() - Method in class com.hazelcast.cp.internal.raft.impl.persistence.RestoredRaftState
 
initialMembers() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
 
InitialMembershipEvent - Class in com.hazelcast.cluster
An event that is sent when a InitialMembershipListener registers itself on a Cluster.
InitialMembershipEvent(Cluster, Set<Member>) - Constructor for class com.hazelcast.cluster.InitialMembershipEvent
 
InitialMembershipListener - Interface in com.hazelcast.cluster
The InitializingMembershipListener is a MembershipListener that first receives a InitialMembershipEvent when it is registered so it immediately knows which members are available.
initialOutputBufferSize - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
initImpl() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockService
 
initImpl() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
Subclasses can implement their custom initialization logic here
initLeadershipTransfer(RaftEndpoint, InternalCompletableFuture) - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Initializes the leadership transfer state, and returns true if the leadership transfer is triggered for the first time and returns false if there is an ongoing leadership transfer process.
InitLeadershipTransferTask - Class in com.hazelcast.cp.internal.raft.impl.task
Initializes the leadership transfer process, if the local Raft node is the leader with RaftNodeStatus.ACTIVE status and the given endpoint is a committed group member.
InitLeadershipTransferTask(RaftNodeImpl, RaftEndpoint, InternalCompletableFuture) - Constructor for class com.hazelcast.cp.internal.raft.impl.task.InitLeadershipTransferTask
 
initMask(String[]) - Method in class com.hazelcast.security.permission.AtomicLongPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.AtomicReferencePermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.CachePermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.CardinalityEstimatorPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.CountDownLatchPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.DurableExecutorServicePermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.ExecutorServicePermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.FlakeIdGeneratorPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.InstancePermission
init mask
initMask(String[]) - Method in class com.hazelcast.security.permission.ListPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.LockPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.MapPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.PNCounterPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.QueuePermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.ReplicatedMapPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.RingBufferPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.ScheduledExecutorPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.SemaphorePermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.TopicPermission
 
initMask(String[]) - Method in class com.hazelcast.security.permission.UserCodeDeploymentPermission
 
initMetadataGroup(long, CPMemberInfo, List<CPMemberInfo>, long) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
InitMetadataRaftGroupOp - Class in com.hazelcast.cp.internal.raftop.metadata
Used during cluster startup by CP members to commit their CP member list to the Metadata group.
InitMetadataRaftGroupOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.InitMetadataRaftGroupOp
 
InitMetadataRaftGroupOp(CPMemberInfo, List<CPMemberInfo>, long) - Constructor for class com.hazelcast.cp.internal.raftop.metadata.InitMetadataRaftGroupOp
 
initNetworking(HazelcastClientInstanceImpl) - Method in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
initPartitionsContainers() - Method in interface com.hazelcast.map.impl.MapServiceContext
 
initPreCandidateState() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Initializes pre-candidate state for pre-voting and grant a vote for local endpoint
initSemaphore(CPGroupId, String, int) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreService
 
InitSemaphoreMessageTask - Class in com.hazelcast.cp.internal.datastructures.semaphore.client
Client message task for InitSemaphoreOp
InitSemaphoreMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.client.InitSemaphoreMessageTask
 
InitSemaphoreOp - Class in com.hazelcast.cp.internal.datastructures.semaphore.operation
Operation for ISemaphore.init(int)
InitSemaphoreOp() - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.operation.InitSemaphoreOp
 
InitSemaphoreOp(String, int) - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.operation.InitSemaphoreOp
 
initSequence(int, long) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingHandler
 
initSrcBuffer() - Method in class com.hazelcast.internal.networking.InboundHandler
Initializes the src buffer.
initSrcBuffer(int) - Method in class com.hazelcast.internal.networking.InboundHandler
Initializes the src buffer.
initUuid(int, UUID) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingHandler
 
initWanReplication(NodeEngine) - Method in class com.hazelcast.map.impl.MapContainer
 
inMemoryFormat - Variable in class com.hazelcast.cache.impl.record.CacheRecordFactory
 
inMemoryFormat - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
data type used to store entries.
inMemoryFormat - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
data type used to store entries.
inMemoryFormat - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReplicatedMapConfigCodec.RequestParameters
data type used to store entries.
inMemoryFormat - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddRingbufferConfigCodec.RequestParameters
in memory format of items in the ringbuffer.
InMemoryFormat - Enum in com.hazelcast.config
Storage format type of values stored in cluster
inMemoryFormat - Variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
InMemoryXmlConfig - Class in com.hazelcast.config
Creates a Config loaded from an in-memory Hazelcast XML String.
InMemoryXmlConfig(String) - Constructor for class com.hazelcast.config.InMemoryXmlConfig
Creates a Config from the provided XML string and uses the System.properties to resolve variables in the XML.
InMemoryXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.InMemoryXmlConfig
Creates a Config from the provided XML string and properties to resolve the variables in the XML.
InMemoryYamlConfig - Class in com.hazelcast.config
Creates a Config loaded from an in-memory Hazelcast YAML String.
InMemoryYamlConfig(String) - Constructor for class com.hazelcast.config.InMemoryYamlConfig
Creates a Config from the provided YAML string and uses the System.properties to resolve variables in the YAML.
InMemoryYamlConfig(String, Properties) - Constructor for class com.hazelcast.config.InMemoryYamlConfig
Creates a Config from the provided YAML string and properties to resolve the variables in the YAML.
innerBeforeRun() - Method in class com.hazelcast.map.impl.journal.MapEventJournalSubscribeOperation
 
innerBeforeRun() - Method in class com.hazelcast.map.impl.operation.AwaitMapFlushOperation
 
innerBeforeRun() - Method in class com.hazelcast.map.impl.operation.EntryBackupOperation
 
innerBeforeRun() - Method in class com.hazelcast.map.impl.operation.EntryOperation
 
innerBeforeRun() - Method in class com.hazelcast.map.impl.operation.MapOperation
 
innerBeforeRun() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
 
innerBeforeRun() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
 
innerBeforeRun() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
 
innerBeforeRun() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
 
innerBeforeRun() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
 
innerBeforeRun() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.AbstractTransactionalMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCommitMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCreateMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionRollbackMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListAddMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListRemoveMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListSizeMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapContainsKeyMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapDeleteMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetForUpdateMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapIsEmptyMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetWithPredicateMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutIfAbsentMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveIfSameMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceIfSameMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSetMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSizeMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesWithPredicateMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapGetMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapPutMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveEntryMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapSizeMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapValueCountMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueOfferMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePeekMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePollMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueSizeMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueTakeMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetAddMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetRemoveMessageTask
 
innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetSizeMessageTask
 
innerClose() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
innerRun() - Method in class com.hazelcast.cp.internal.raft.impl.handler.AbstractResponseHandlerTask
 
innerRun() - Method in class com.hazelcast.cp.internal.raft.impl.handler.AppendRequestHandlerTask
 
innerRun() - Method in class com.hazelcast.cp.internal.raft.impl.handler.InstallSnapshotHandlerTask
 
innerRun() - Method in class com.hazelcast.cp.internal.raft.impl.handler.PreVoteRequestHandlerTask
 
innerRun() - Method in class com.hazelcast.cp.internal.raft.impl.handler.TriggerLeaderElectionHandlerTask
 
innerRun() - Method in class com.hazelcast.cp.internal.raft.impl.handler.VoteRequestHandlerTask
 
innerRun() - Method in class com.hazelcast.cp.internal.raft.impl.task.LeaderElectionTask
 
innerRun() - Method in class com.hazelcast.cp.internal.raft.impl.task.LeaderElectionTimeoutTask
 
innerRun() - Method in class com.hazelcast.cp.internal.raft.impl.task.PreVoteTask
 
innerRun() - Method in class com.hazelcast.cp.internal.raft.impl.task.PreVoteTimeoutTask
 
innerRun() - Method in class com.hazelcast.cp.internal.raft.impl.task.RaftNodeStatusAwareTask
 
InPredicate - Class in com.hazelcast.query.impl.predicates
In Predicate
InPredicate() - Constructor for class com.hazelcast.query.impl.predicates.InPredicate
 
InPredicate(String, Comparable...) - Constructor for class com.hazelcast.query.impl.predicates.InPredicate
 
inProgress() - Method in enum com.hazelcast.hotrestart.BackupTaskState
Returns if the backup task is in progress.
inputOutputFactory - Variable in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
InputOutputFactory - Interface in com.hazelcast.internal.serialization
 
inputThreadCount(int) - Method in class com.hazelcast.internal.networking.nio.NioNetworking.Context
 
insert(Object, QueryableEntry, IndexOperationStats) - Method in class com.hazelcast.query.impl.BaseIndexStore
 
insert(Object, QueryableEntry, IndexOperationStats) - Method in interface com.hazelcast.query.impl.IndexStore
Inserts the given entry into this index store under the given value acting as an index key.
insertBefore(Node, Node) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
insertMigratedData(int, Map<String, Map<Data, MultiMapValue>>) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
inspectOutOfMemoryError(Throwable) - Static method in class com.hazelcast.instance.impl.OutOfMemoryErrorDispatcher
 
INSTALL_SNAPSHOT - Static variable in class com.hazelcast.cp.internal.raft.impl.RaftDataSerializerHook
 
INSTALL_SNAPSHOT_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
InstallSnapshot - Class in com.hazelcast.cp.internal.raft.impl.dto
Struct for InstallSnapshot RPC.
InstallSnapshot() - Constructor for class com.hazelcast.cp.internal.raft.impl.dto.InstallSnapshot
 
InstallSnapshot(RaftEndpoint, int, SnapshotEntry, long) - Constructor for class com.hazelcast.cp.internal.raft.impl.dto.InstallSnapshot
 
installSnapshot(SnapshotEntry) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Restores the snapshot sent by the leader if it's not applied before.
InstallSnapshotHandlerTask - Class in com.hazelcast.cp.internal.raft.impl.handler
Handles InstallSnapshot request sent by leader.
InstallSnapshotHandlerTask(RaftNodeImpl, InstallSnapshot) - Constructor for class com.hazelcast.cp.internal.raft.impl.handler.InstallSnapshotHandlerTask
 
InstallSnapshotOp - Class in com.hazelcast.cp.internal.operation.integration
Carries a InstallSnapshot RPC from a Raft group leader to a follower
InstallSnapshotOp() - Constructor for class com.hazelcast.cp.internal.operation.integration.InstallSnapshotOp
 
InstallSnapshotOp(CPGroupId, InstallSnapshot) - Constructor for class com.hazelcast.cp.internal.operation.integration.InstallSnapshotOp
 
instance(HazelcastInstanceImpl) - Method in class com.hazelcast.cluster.impl.MemberImpl.Builder
 
INSTANCE - Static variable in class com.hazelcast.config.security.DefaultAuthenticationConfig
Singleton instance.
INSTANCE - Static variable in class com.hazelcast.cp.internal.persistence.NopCPMetadataStore
 
INSTANCE - Static variable in class com.hazelcast.cp.internal.persistence.NopCPPersistenceService
 
INSTANCE - Static variable in class com.hazelcast.cp.internal.raft.impl.persistence.NopRaftStateStore
Non-persisting RaftStateStore instance
INSTANCE - Static variable in class com.hazelcast.cp.internal.raft.impl.util.PostponedResponse
 
INSTANCE - Static variable in class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService
 
INSTANCE - Static variable in class com.hazelcast.internal.eviction.impl.strategy.sampling.SamplingEvictionStrategy
 
INSTANCE - Static variable in class com.hazelcast.internal.json.NonTerminalJsonValue
 
instance - Variable in class com.hazelcast.internal.management.TimedMemberStateFactory
 
INSTANCE - Static variable in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
INSTANCE - Static variable in class com.hazelcast.internal.memory.impl.ByteArrayAccessStrategy
 
INSTANCE - Static variable in class com.hazelcast.internal.memory.impl.ByteBufferAccessStrategy
 
INSTANCE - Static variable in class com.hazelcast.internal.memory.impl.CustomByteAccessStrategy
 
INSTANCE - Static variable in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
INSTANCE - Static variable in class com.hazelcast.internal.nio.ascii.AllowingTextProtocolFilter
 
INSTANCE - Static variable in class com.hazelcast.internal.partition.NonFragmentedServiceNamespace
 
INSTANCE - Static variable in class com.hazelcast.map.eviction.LFUEvictionPolicy
LFU eviction policy instance.
INSTANCE - Static variable in class com.hazelcast.map.eviction.LRUEvictionPolicy
LRU eviction policy instance.
INSTANCE - Static variable in class com.hazelcast.map.eviction.RandomEvictionPolicy
Random eviction policy instance.
INSTANCE - Static variable in class com.hazelcast.map.impl.JsonMetadataInitializer
 
INSTANCE - Static variable in class com.hazelcast.partition.strategy.StringAndPartitionAwarePartitioningStrategy
 
INSTANCE - Static variable in class com.hazelcast.partition.strategy.StringPartitioningStrategy
 
INSTANCE - Static variable in class com.hazelcast.projection.impl.IdentityProjection
 
INSTANCE - Static variable in class com.hazelcast.query.impl.getters.JsonGetter
 
INSTANCE - Static variable in class com.hazelcast.query.impl.predicates.FalsePredicate
An instance of the FalsePredicate.
INSTANCE - Static variable in class com.hazelcast.query.impl.predicates.TruePredicate
An instance of the TruePredicate.
INSTANCE - Static variable in class com.hazelcast.spi.impl.eventservice.impl.TrueEventFilter
 
InstanceMBean - Class in com.hazelcast.internal.jmx
Management bean for HazelcastInstance
InstanceMBean(HazelcastInstanceImpl, ManagementService) - Constructor for class com.hazelcast.internal.jmx.InstanceMBean
 
instanceOf(Class) - Static method in class com.hazelcast.query.Predicates
Creates an instance of predicate that will pass entries for which the value class is an instanceof the given klass.
INSTANCEOF_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
InstanceOfPredicate - Class in com.hazelcast.query.impl.predicates
Predicate version of `instaceof` operator from Java.
InstanceOfPredicate(Class) - Constructor for class com.hazelcast.query.impl.predicates.InstanceOfPredicate
 
InstanceOfPredicate() - Constructor for class com.hazelcast.query.impl.predicates.InstanceOfPredicate
 
InstancePermission - Class in com.hazelcast.security.permission
TODO: Object Permission
InstancePermission(String, String...) - Constructor for class com.hazelcast.security.permission.InstancePermission
 
InstantiationUtils - Class in com.hazelcast.internal.util
Convenience for class instantiation.
instrument(NodeEngine) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
instrument(NodeEngine) - Method in class com.hazelcast.map.impl.MapStoreWrapper
 
Int2ObjectHashMap<V> - Class in com.hazelcast.internal.util.collection
Map implementation specialized for int keys using open addressing and linear probing for cache-efficient access.
Int2ObjectHashMap() - Constructor for class com.hazelcast.internal.util.collection.Int2ObjectHashMap
 
Int2ObjectHashMap(int) - Constructor for class com.hazelcast.internal.util.collection.Int2ObjectHashMap
 
Int2ObjectHashMap(int, double) - Constructor for class com.hazelcast.internal.util.collection.Int2ObjectHashMap
Construct a new map allowing a configuration for initial capacity and load factor.
Int2ObjectHashMap.KeyIterator - Class in com.hazelcast.internal.util.collection
Adds an unboxed next() method to the standard Iterator interface.
Int2ObjectHashMap.KeySet - Class in com.hazelcast.internal.util.collection
Adds non-boxing methods to the standard Set interface.
INT_AVG - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
INT_SIZE_IN_BYTES - Static variable in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
INT_SIZE_IN_BYTES - Static variable in class com.hazelcast.internal.nio.Bits
Integer size in bytes
INT_SUM - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
INTEGER_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
IntegerArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.IntegerArraySerializer
 
IntegerAverageAggregator<I> - Class in com.hazelcast.aggregation.impl
 
IntegerAverageAggregator() - Constructor for class com.hazelcast.aggregation.impl.IntegerAverageAggregator
 
IntegerAverageAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.IntegerAverageAggregator
 
integerAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
integerAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
integerMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
integerMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
integerMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
integerMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
IntegerSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.IntegerSerializer
 
integerSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
integerSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
IntegerSumAggregator<I> - Class in com.hazelcast.aggregation.impl
 
IntegerSumAggregator() - Constructor for class com.hazelcast.aggregation.impl.IntegerSumAggregator
 
IntegerSumAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.IntegerSumAggregator
 
interceptAfter(Credentials, String, String, String) - Method in interface com.hazelcast.security.SecurityContext
intercepts a request after process if any SecurityInterceptor configured Any exception thrown during interception will be ignored
interceptAfterGet(String, Object) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
 
interceptAfterPut(String, Object) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
 
interceptAfterRemove(String, Object) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
 
interceptBefore(Credentials, String, String, String, Object[]) - Method in interface com.hazelcast.security.SecurityContext
intercepts a request before process if any SecurityInterceptor configured
interceptError(Throwable) - Method in class com.hazelcast.internal.networking.ChannelHandler
Intercepts an error that is thrown while processing the inbound or outbound pipeline.
interceptGet(String, Object) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
 
interceptGet(Object) - Method in interface com.hazelcast.map.MapInterceptor
Intercepts the get operation before returning value.
interceptLockOperation() - Method in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
interceptor - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddInterceptorCodec.RequestParameters
interceptor to add
INTERCEPTOR_INFO - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
InterceptorInfo() - Constructor for class com.hazelcast.map.impl.operation.PostJoinMapOperation.InterceptorInfo
 
InterceptorRegistry - Class in com.hazelcast.map.impl
Registry for IMap interceptors Interceptors are read mostly and this registry keeps all registered interceptor in an array to easily iterate on them.
InterceptorRegistry() - Constructor for class com.hazelcast.map.impl.InterceptorRegistry
 
interceptorRegistry - Variable in class com.hazelcast.map.impl.MapContainer
 
interceptPut(String, Object, Object) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
 
interceptPut(Object, Object) - Method in interface com.hazelcast.map.MapInterceptor
Intercepts the put operation before modifying the map data.
interceptRemove(String, Object) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
 
interceptRemove(Object) - Method in interface com.hazelcast.map.MapInterceptor
Intercepts the remove operation before removing the data.
interceptResponse(Object) - Method in class com.hazelcast.executor.impl.ExecutionCallbackAdapter
 
interceptSocket(EndpointQualifier, Socket, boolean) - Method in interface com.hazelcast.internal.nio.IOService
 
interceptSocket(EndpointQualifier, Socket, boolean) - Method in class com.hazelcast.internal.nio.NodeIOService
 
interfaces - Variable in class com.hazelcast.config.EndpointConfig
 
InterfacesConfig - Class in com.hazelcast.config
Contains the configuration for Interfaces.
InterfacesConfig() - Constructor for class com.hazelcast.config.InterfacesConfig
 
INTERNAL_EXECUTOR_POOL_SIZE - Static variable in class com.hazelcast.client.impl.spi.impl.ClientExecutionServiceImpl
 
InternalCachePartitionLostListenerAdapter - Class in com.hazelcast.cache.impl.event
 
InternalCachePartitionLostListenerAdapter(CachePartitionLostListener) - Constructor for class com.hazelcast.cache.impl.event.InternalCachePartitionLostListenerAdapter
 
InternalCompletableFuture<V> - Class in com.hazelcast.spi.impl
An extension to CompletableFuture supporting a joinInternal() variant with more relaxed exception throwing conventions.
InternalCompletableFuture() - Constructor for class com.hazelcast.spi.impl.InternalCompletableFuture
 
InternalEventJournalCacheEvent - Class in com.hazelcast.cache.impl.journal
The event journal item for map events.
InternalEventJournalCacheEvent() - Constructor for class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
 
InternalEventJournalCacheEvent(Data, Data, Data, int) - Constructor for class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
 
InternalEventJournalMapEvent - Class in com.hazelcast.map.impl.journal
The event journal item for map events.
InternalEventJournalMapEvent() - Constructor for class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
 
InternalEventJournalMapEvent(Data, Data, Data, int) - Constructor for class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
 
InternalHotRestartService - Interface in com.hazelcast.internal.hotrestart
Internal service for interacting with hot restart related functionalities (e.g.
InternalIndex - Interface in com.hazelcast.query.impl
Provides the private index API.
InternalListMultiMap<K,V> - Class in com.hazelcast.internal.util.collection
Simplistic implementation of MultiMap.
InternalListMultiMap() - Constructor for class com.hazelcast.internal.util.collection.InternalListMultiMap
 
InternalMapListenerAdapter - Class in com.hazelcast.map.impl
Internal-usage-only adapter which wraps all MapListener sub-interfaces into a ListenerAdapter.
InternalPartition - Interface in com.hazelcast.internal.partition
 
InternalPartitionImpl - Class in com.hazelcast.internal.partition.impl
 
InternalPartitionImpl(int, PartitionReplicaInterceptor, PartitionReplica, PartitionReplica[]) - Constructor for class com.hazelcast.internal.partition.impl.InternalPartitionImpl
 
InternalPartitionService - Interface in com.hazelcast.internal.partition
 
InternalPartitionServiceImpl - Class in com.hazelcast.internal.partition.impl
The InternalPartitionService implementation.
InternalPartitionServiceImpl(Node) - Constructor for class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
InternalProxyService - Interface in com.hazelcast.spi.impl.proxyservice
The API for the internal ProxyService.
InternalQueryCache<K,V> - Interface in com.hazelcast.map.impl.querycache.subscriber
Internal interface which adds some internally used methods to QueryCache interface.
InternalReplicatedMapStorage<K,V> - Class in com.hazelcast.replicatedmap.impl.record
This class is meant to encapsulate the actual storage system and support automatic waiting for finishing load operations if configured in the ReplicatedMapConfig
InternalReplicatedMapStorage() - Constructor for class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
 
InternalSerializationService - Interface in com.hazelcast.internal.serialization
 
InternalSetMultimap<K,V> - Class in com.hazelcast.internal.util.collection
Simplistic implementation of MultiMap.
InternalSetMultimap() - Constructor for class com.hazelcast.internal.util.collection.InternalSetMultimap
 
internalToString() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.BlockingResource
 
InternalWanReplicationEvent - Interface in com.hazelcast.wan.impl
Private API for WAN replication events
InternalWanReplicationPublisher<T> - Interface in com.hazelcast.wan.impl
Methods exposed on WAN publishers for internal use.
interrupt - Variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnAddressCodec.RequestParameters
If true, then the thread interrupt call can be used to cancel the thread, otherwise interrupt can not be used.
interrupt - Variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnPartitionCodec.RequestParameters
If true, then the thread interrupt call can be used to cancel the thread, otherwise interrupt can not be used.
interruptBackupTask() - Method in interface com.hazelcast.hotrestart.HotRestartService
Interrupts the backup tasks on each cluster member if one is currently running.
interruptBackupTask() - Method in class com.hazelcast.internal.hotrestart.NoOpHotRestartService
 
INTERRUPTED - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
interruptLocalBackupTask() - Method in interface com.hazelcast.hotrestart.HotRestartService
Interrupts the local backup task if one is currently running.
interruptLocalBackupTask() - Method in class com.hazelcast.internal.hotrestart.NoOpHotRestartService
 
intersection(String[], String[]) - Static method in class com.hazelcast.internal.util.StringUtil
Returns intersection of given String arrays.
intersects(PartitionIdSet) - Method in class com.hazelcast.internal.util.collection.PartitionIdSet
Returns whether the intersection of this set with given argument is not empty.
IntHashSet - Class in com.hazelcast.internal.util.collection
Simple fixed-size int hashset.
IntHashSet(int, int) - Constructor for class com.hazelcast.internal.util.collection.IntHashSet
 
IntIterator - Class in com.hazelcast.internal.util.collection
An iterator for a sequence of primitive integers.
IntIterator(int, int[]) - Constructor for class com.hazelcast.internal.util.collection.IntIterator
Construct an Iterator over an array of primitives ints.
intIterator() - Method in class com.hazelcast.internal.util.collection.PartitionIdSet
 
IntMemArrayQuickSorter - Class in com.hazelcast.internal.util.sort
QuickSorter implementation for a memory block which stores an array of ints.
IntMemArrayQuickSorter(MemoryAccessor, long) - Constructor for class com.hazelcast.internal.util.sort.IntMemArrayQuickSorter
 
INVALID_ADDRESS - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
INVALID_CONFIGURATION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
INVALID_FENCE - Static variable in interface com.hazelcast.cp.lock.FencedLock
Representation of a failed lock attempt where the caller thread has not acquired the lock
INVALID_ITEM_ID - Static variable in class com.hazelcast.collection.impl.collection.CollectionContainer
 
InvalidAddressException(String) - Constructor for exception com.hazelcast.internal.util.AddressUtil.InvalidAddressException
 
InvalidAddressException(String, boolean) - Constructor for exception com.hazelcast.internal.util.AddressUtil.InvalidAddressException
 
invalidate(K) - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
invalidate(K) - Method in class com.hazelcast.internal.nearcache.impl.store.BaseHeapNearCacheRecordStore
 
invalidate(K) - Method in interface com.hazelcast.internal.nearcache.NearCache
Removes the value associated with the given key and increases the invalidation statistics.
invalidate(K) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
Removes the value associated with the given key and increases the invalidation statistics.
invalidate(InternalIndex) - Method in class com.hazelcast.query.impl.ConverterCache
Invalidates this cache after the addition of the given index to the Indexes for which this cache was constructed for.
invalidate() - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
invalidateAll(UUID) - Method in class com.hazelcast.spi.impl.operationparker.impl.WaitSet
 
invalidateAllKeys(String, UUID) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
Invalidates all keys from Near Caches of supplied data structure name.
invalidateAllKeysInNearCaches() - Method in class com.hazelcast.map.impl.operation.MapOperation
This method helps to add clearing Near Cache event only from one-partition which matches partitionId of the map name.
invalidateEntry(Data, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
invalidateEntry(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
invalidateFuturesFrom(long) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Invalidates futures registered with indexes >= entryIndex.
invalidateInternal(Invalidation, int) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.BatchInvalidator
 
invalidateInternal(Invalidation, int) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
 
invalidateInternal(Invalidation, int) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.NonStopInvalidator
 
invalidateKey(Data, String, UUID) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
Invalidates supplied key from Near Caches of supplied data structure name.
invalidateNearCache(List<Data>) - Method in class com.hazelcast.map.impl.operation.MapOperation
 
invalidateNearCache(Data) - Method in class com.hazelcast.map.impl.operation.MapOperation
 
invalidateNearCache(Object) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
invalidateSession(RaftGroupId, long) - Method in class com.hazelcast.cp.internal.session.AbstractProxySessionManager
Invalidates the given session.
invalidateSession(long) - Method in class com.hazelcast.cp.internal.session.SessionAwareProxy
Invalidates the given session.
Invalidation - Class in com.hazelcast.internal.nearcache.impl.invalidation
Root interface for Near Cache invalidation data.
Invalidation() - Constructor for class com.hazelcast.internal.nearcache.impl.invalidation.Invalidation
 
Invalidation(String) - Constructor for class com.hazelcast.internal.nearcache.impl.invalidation.Invalidation
 
Invalidation(String, UUID, UUID, long) - Constructor for class com.hazelcast.internal.nearcache.impl.invalidation.Invalidation
 
InvalidationListener - Interface in com.hazelcast.map.impl.nearcache.invalidation
Used to receive invalidation events from an IMap
invalidationListenerCount - Variable in class com.hazelcast.map.impl.MapContainer
Holds number of registered InvalidationListener from clients.
InvalidationMetaDataFetcher - Class in com.hazelcast.internal.nearcache.impl.invalidation
Runs on Near Cache side, an instance of this task is responsible for fetching of all Near Caches' remote metadata like last sequence numbers and partition UUIDs.
InvalidationMetaDataFetcher(ILogger) - Constructor for class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationMetaDataFetcher
 
InvalidationMetaDataFetcher.MetadataHolder - Class in com.hazelcast.internal.nearcache.impl.invalidation
 
InvalidationQueue<T> - Class in com.hazelcast.internal.nearcache.impl.invalidation
 
InvalidationQueue() - Constructor for class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationQueue
 
InvalidationUtils - Class in com.hazelcast.internal.nearcache.impl.invalidation
Utils for invalidations.
Invalidator - Class in com.hazelcast.internal.nearcache.impl.invalidation
Contains shared functionality for Near Cache invalidation.
Invalidator(String, Function<EventRegistration, Boolean>, NodeEngine) - Constructor for class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
 
invalidator - Variable in class com.hazelcast.map.impl.nearcache.MapNearCacheManager
 
InvalidConfigurationException - Exception in com.hazelcast.config
A InvalidConfigurationException is thrown when an Hazelcast faces an invalid configuration.
InvalidConfigurationException(String) - Constructor for exception com.hazelcast.config.InvalidConfigurationException
Creates a InvalidConfigurationException with the given message.
InvalidConfigurationException(String, Throwable) - Constructor for exception com.hazelcast.config.InvalidConfigurationException
Constructs a new runtime exception with the specified detail message and cause.
inverse(ClientSelector) - Static method in class com.hazelcast.client.impl.ClientSelectors
 
invertBit(byte, int) - Static method in class com.hazelcast.internal.nio.Bits
Inverts n-th bit of the byte value
invertBit(int, int) - Static method in class com.hazelcast.internal.nio.Bits
Inverts n-th bit of the integer value
Invocation<T> - Class in com.hazelcast.spi.impl.operationservice.impl
Evaluates the invocation of an Operation.
INVOCATION_MAX_RETRY_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Maximum number of retries for an invocation.
INVOCATION_RETRY_PAUSE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Pause time between each retry cycle of an invocation in milliseconds.
INVOCATION_RETRY_PAUSE_MILLIS - Static variable in class com.hazelcast.client.properties.ClientProperty
Pause time between each retry cycle of an invocation in milliseconds.
INVOCATION_TIMEOUT_SECONDS - Static variable in class com.hazelcast.client.properties.ClientProperty
When an invocation gets an exception because : - Member throws an exception.
INVOCATION_TRY_COUNT - Static variable in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
InvocationBuilder - Class in com.hazelcast.spi.impl.operationservice
The InvocationBuilder is responsible for building an invocation of an operation and invoking it.
InvocationBuilder(String, Operation, int, Address) - Constructor for class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Creates an InvocationBuilder
InvocationFuture<E> - Class in com.hazelcast.spi.impl.operationservice.impl
The InvocationFuture is the InternalCompletableFuture that waits on the completion of an Invocation.
InvocationMonitor - Class in com.hazelcast.spi.impl.operationservice.impl
The InvocationMonitor monitors all pending invocations and determines if there are any problems like timeouts.
InvocationPlugin - Class in com.hazelcast.internal.diagnostics
A DiagnosticsPlugin that displays all invocations that have been executing for some time.
InvocationPlugin(NodeEngineImpl) - Constructor for class com.hazelcast.internal.diagnostics.InvocationPlugin
 
InvocationRegistry - Class in com.hazelcast.spi.impl.operationservice.impl
Responsible for the registration of all pending invocations.
InvocationRegistry(ILogger, CallIdSequence) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
 
invocationRetryPauseMillis - Variable in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
invocations - Variable in class com.hazelcast.internal.management.dto.SlowOperationDTO
 
invocationTimeoutMillis - Variable in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
invocationToString() - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
invocationToString() - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
invocationToString() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationFuture
 
invocationUid - Variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchAwaitCodec.RequestParameters
UID of this invocation
invocationUid - Variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchCountDownCodec.RequestParameters
UID of this invocation
invocationUid - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockLockCodec.RequestParameters
UID of this invocation
invocationUid - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockTryLockCodec.RequestParameters
UID of this invocation
invocationUid - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockUnlockCodec.RequestParameters
UID of this invocation
invocationUid - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreAcquireCodec.RequestParameters
UID of this invocation
invocationUid - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreChangeCodec.RequestParameters
UID of this invocation
invocationUid - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreDrainCodec.RequestParameters
UID of this invocation
invocationUid - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreReleaseCodec.RequestParameters
UID of this invocation
invocationUid - Variable in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKey
 
invocationUid() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKey
Returns unique id of the committed operation which is provided by the caller.
invocationUid() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKeyContainer
 
InvocationUtil - Class in com.hazelcast.internal.util
Utility methods for invocations.
invoke(Data, EntryProcessor, Object[], int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
invoke(K, EntryProcessor<K, V, T>, Object...) - Method in class com.hazelcast.cache.impl.CacheProxy
 
invoke(Data, EntryProcessor, Object[], int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Invokes an EntryProcessor against the Cache.Entry specified by the provided key.
invoke(K, EntryProcessor<K, V, T>, Object...) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
invoke(ClientMessage, int) - Method in class com.hazelcast.client.impl.proxy.ClientRingbufferProxy
 
invoke(ClientMessage, Object, HazelcastClientInstanceImpl, Connection) - Static method in class com.hazelcast.client.impl.proxy.txn.ClientTransactionUtil
Handles the invocation exception for transactions so that users will not see internal exceptions.
invoke(Object) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientInvokerWrapper
 
invoke(ClientMessage, Object) - Method in class com.hazelcast.client.impl.spi.ClientProxy
 
invoke(ClientMessage) - Method in class com.hazelcast.client.impl.spi.ClientProxy
 
invoke() - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocation
 
invoke(ClientRegistrationKey, Connection) - Method in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
invoke(CollectionOperation) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
invoke(CPGroupId, RaftOp) - Method in class com.hazelcast.cp.internal.RaftInvocationManager
 
invoke(K, EntryProcessor<K, V, T>, Object...) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
invoke(K, EntryProcessor<K, V, T>, Object...) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
invoke(K, EntryProcessor<K, V, T>, Object...) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
invoke(K, EntryProcessor<K, V, T>, Object...) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
invoke(K, EntryProcessor<K, V, T>, Object...) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
invoke(String, Object[], String[]) - Method in class com.hazelcast.internal.jmx.HazelcastMBean
 
invoke(String, Object[], String[]) - Method in class com.hazelcast.internal.metrics.jmx.MetricsMBean
 
invoke(Operation, int) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
invoke(Object) - Method in interface com.hazelcast.map.impl.querycache.InvokerWrapper
 
invoke(Object) - Method in class com.hazelcast.map.impl.querycache.NodeInvokerWrapper
 
invoke() - Method in class com.hazelcast.scheduledexecutor.impl.InvokeOnMembers
Executes the operation on all targets.
invoke(String, Operation, int) - Method in class com.hazelcast.spi.impl.merge.AbstractContainerMerger
Invokes the given merge operation.
invoke() - Method in class com.hazelcast.spi.impl.operationservice.impl.Invocation
 
invoke() - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
 
invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in class com.hazelcast.cache.impl.CacheProxy
 
invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
invokeAll(Collection<? extends Callable<T>>) - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
invokeAll(Collection<? extends Callable<T>>) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
invokeAll(Collection<? extends Callable<T>>) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
invokeAll(Collection<? extends Callable<T>>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
invokeAll(Collection<? extends Callable<T>>) - Method in class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
invokeAny(Collection<? extends Callable<T>>) - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
invokeAny(Collection<? extends Callable<T>>) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
invokeAny(Collection<? extends Callable<T>>) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
invokeAny(Collection<? extends Callable<T>>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
invokeAny(Collection<? extends Callable<T>>) - Method in class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
invokeAsync() - Method in class com.hazelcast.spi.impl.operationservice.impl.Invocation
 
invokeBackupExpiryOperation(Collection<ExpiredKey>, int, int, RS) - Method in class com.hazelcast.internal.eviction.ToBackupSender
 
invokeInternal(Object, Data, Object[]) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
invokeMethod(Object, String) - Static method in class com.hazelcast.query.impl.getters.ReflectionHelper
 
invokeOnAddress(ClientMessage, Address) - Method in class com.hazelcast.client.impl.spi.ClientProxy
 
invokeOnAllPartitions(Object) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientInvokerWrapper
 
invokeOnAllPartitions(Object) - Method in interface com.hazelcast.map.impl.querycache.InvokerWrapper
 
invokeOnAllPartitions(Object) - Method in class com.hazelcast.map.impl.querycache.NodeInvokerWrapper
 
invokeOnAllPartitions(String, OperationFactory) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
invokeOnAllPartitions(String, OperationFactory) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Invokes a set of operations on each partition.
invokeOnAllPartitionsAsync(String, OperationFactory) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
invokeOnAllPartitionsAsync(String, OperationFactory) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Invokes a set of operations on selected set of all partitions in an async way.
invokeOnConnection(ClientInvocation, ClientConnection) - Method in interface com.hazelcast.client.impl.spi.ClientInvocationService
 
invokeOnConnection(ClientInvocation, ClientConnection) - Method in class com.hazelcast.client.impl.spi.impl.NonSmartClientInvocationService
 
invokeOnConnection(ClientInvocation, ClientConnection) - Method in class com.hazelcast.client.impl.spi.impl.SmartClientInvocationService
 
InvokeOnMembers - Class in com.hazelcast.scheduledexecutor.impl
Executes an operation on a set of targets.
InvokeOnMembers(NodeEngine, String, Supplier<Operation>, Collection<Member>) - Constructor for class com.hazelcast.scheduledexecutor.impl.InvokeOnMembers
 
invokeOnPartition(ClientMessage, int) - Method in class com.hazelcast.client.impl.spi.ClientProxy
 
invokeOnPartition(AbstractUnsafeRaftOp) - Method in class com.hazelcast.cp.internal.RaftInvocationManager
 
invokeOnPartition(Operation) - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
invokeOnPartition(String, Operation, int) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
invokeOnPartition(Operation) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
invokeOnPartition(String, Operation, int) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
 
invokeOnPartition(Operation) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Executes an operation on a partition.
invokeOnPartitionAsync(String, Operation, int) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
invokeOnPartitionAsync(String, Operation, int) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
 
invokeOnPartitionInterruptibly(ClientMessage, int) - Method in class com.hazelcast.client.impl.spi.ClientProxy
 
invokeOnPartitionOwner(Object, int) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientInvokerWrapper
 
invokeOnPartitionOwner(ClientInvocation, int) - Method in interface com.hazelcast.client.impl.spi.ClientInvocationService
 
invokeOnPartitionOwner(ClientInvocation, int) - Method in class com.hazelcast.client.impl.spi.impl.NonSmartClientInvocationService
 
invokeOnPartitionOwner(ClientInvocation, int) - Method in class com.hazelcast.client.impl.spi.impl.SmartClientInvocationService
 
invokeOnPartitionOwner(Object, int) - Method in interface com.hazelcast.map.impl.querycache.InvokerWrapper
 
invokeOnPartitionOwner(Object, int) - Method in class com.hazelcast.map.impl.querycache.NodeInvokerWrapper
 
invokeOnPartitions(String, OperationFactory, Collection<Integer>) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
invokeOnPartitions(String, OperationFactory, int[]) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
invokeOnPartitions(String, OperationFactory, Collection<Integer>) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Invokes a set of operations on selected set of partitions.
invokeOnPartitions(String, OperationFactory, int[]) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Invokes a set of operations on selected set of partitions.
invokeOnPartitionsAsync(String, OperationFactory, Collection<Integer>) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
invokeOnPartitionsAsync(String, OperationFactory, Map<Address, List<Integer>>) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
invokeOnPartitionsAsync(String, OperationFactory, Collection<Integer>) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Invokes a set of operations on selected set of partitions in an async way.
invokeOnPartitionsAsync(String, OperationFactory, Map<Address, List<Integer>>) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Invokes a set of operations on selected set of partitions in an async way.
invokeOnRandomTarget(ClientInvocation) - Method in interface com.hazelcast.client.impl.spi.ClientInvocationService
 
invokeOnRandomTarget(ClientInvocation) - Method in class com.hazelcast.client.impl.spi.impl.NonSmartClientInvocationService
 
invokeOnRandomTarget(ClientInvocation) - Method in class com.hazelcast.client.impl.spi.impl.SmartClientInvocationService
 
invokeOnStableClusterSerial(NodeEngine, Supplier<? extends Operation>, int) - Static method in class com.hazelcast.internal.util.InvocationUtil
Invoke operation on all cluster members.
invokeOnTarget(Object, Address) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientInvokerWrapper
 
invokeOnTarget(ClientInvocation, Address) - Method in interface com.hazelcast.client.impl.spi.ClientInvocationService
 
invokeOnTarget(ClientInvocation, Address) - Method in class com.hazelcast.client.impl.spi.impl.NonSmartClientInvocationService
 
invokeOnTarget(ClientInvocation, Address) - Method in class com.hazelcast.client.impl.spi.impl.SmartClientInvocationService
 
invokeOnTarget(Object, Address) - Method in interface com.hazelcast.map.impl.querycache.InvokerWrapper
 
invokeOnTarget(Object, Address) - Method in class com.hazelcast.map.impl.querycache.NodeInvokerWrapper
 
invokeOnTarget(String, Operation, Address) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
invokeOnTarget(String, Operation, Address) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
 
InvokerWrapper - Interface in com.hazelcast.map.impl.querycache
Provides abstraction over client and node side invocations.
invokeUrgent() - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocation
 
IO - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
IO_BALANCER_INTERVAL_SECONDS - Static variable in class com.hazelcast.client.properties.ClientProperty
The interval in seconds between IOBalancer executions.
IO_BALANCER_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The interval in seconds between IOBalancer executions.
IO_EXECUTOR - Static variable in interface com.hazelcast.spi.impl.executionservice.ExecutionService
Name of the io executor.
IO_INPUT_THREAD_COUNT - Static variable in class com.hazelcast.client.properties.ClientProperty
Controls the number of IO input threads.
IO_INPUT_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Controls the number of socket input threads.
IO_OUTPUT_THREAD_COUNT - Static variable in class com.hazelcast.client.properties.ClientProperty
Controls the number of IO output threads.
IO_OUTPUT_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Controls the number of socket output threads.
IO_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
The number of threads doing socket input and the number of threads doing socket output.
IO_WRITE_THROUGH_ENABLED - Static variable in class com.hazelcast.client.properties.ClientProperty
Optimization that allows sending of packets over the network to be done on the calling thread if the conditions are right.
IO_WRITE_THROUGH_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Optimization that allows sending of packets over the network to be done on the calling thread if the conditions are right.
IOBalancer - Class in com.hazelcast.internal.networking.nio.iobalancer
It attempts to detect and fix a selector imbalance problem.
IOBalancer(NioThread[], NioThread[], String, int, LoggingService) - Constructor for class com.hazelcast.internal.networking.nio.iobalancer.IOBalancer
 
IOService - Interface in com.hazelcast.internal.nio
 
ioService - Variable in class com.hazelcast.internal.nio.tcp.AbstractChannelInitializer
 
ioService - Variable in class com.hazelcast.internal.nio.tcp.DefaultChannelInitializerProvider
 
IOUtil - Class in com.hazelcast.internal.nio
 
ipAddress - Variable in class com.hazelcast.internal.management.dto.ClientEndPointDTO
Client's IP address (without port) or null if client's address is unresolved
IPartition - Interface in com.hazelcast.spi.partition
Represents a Partition.
IPartitionLostEvent - Interface in com.hazelcast.spi.partition
IPartitionService - Interface in com.hazelcast.spi.partition
An SPI service for accessing partition related information.
IPermissionPolicy - Interface in com.hazelcast.security
IPermissionPolicy is used to determine any Subject's permissions to perform a security sensitive Hazelcast operation.
IPredicate<T> - Interface in com.hazelcast.map.impl.mapstore.writebehind
Represents a predicate (boolean-valued function) of one argument.
ipSelector(String) - Static method in class com.hazelcast.client.impl.ClientSelectors
Works with AddressUtil.mathInterface
IQueue<E> - Interface in com.hazelcast.collection
Concurrent, blocking, distributed, observable queue.
is(T, T...) - Method in class com.hazelcast.internal.util.StateMachine
Check if current state is one of given states
is(String) - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
is(String) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
is2BytesAligned(long) - Static method in class com.hazelcast.internal.memory.impl.AlignmentUtil
 
is32bitJVM() - Static method in class com.hazelcast.internal.util.JVMUtil
 
is4BytesAligned(long) - Static method in class com.hazelcast.internal.memory.impl.AlignmentUtil
 
is8BytesAligned(long) - Static method in class com.hazelcast.internal.memory.impl.AlignmentUtil
 
IS_CANCELED_OP - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
IS_DONE_OP - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
IS_EMPTY - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
IS_EMPTY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
IS_EMPTY - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
IS_EMPTY_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
IS_EVENT_FLAG - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
IS_FINAL_FLAG - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
IS_KEYLOAD_FINISHED - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
IS_LOCKED - Static variable in class com.hazelcast.internal.locksupport.LockDataSerializerHook
 
IS_NULL_FLAG - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
IS_PARTITION_LOADED - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
IS_PARTITION_LOADED_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
IS_PLATFORM_BIG_ENDIAN - Static variable in class com.hazelcast.internal.memory.impl.AlignmentUtil
 
isA(Class<T>) - Method in interface com.hazelcast.internal.yaml.YamlScalar
Checks if the value of this node is the given type
isA(Class<T>) - Method in class com.hazelcast.internal.yaml.YamlScalarImpl
 
isAcceptedSuffixConfigured(String, Collection<String>) - Static method in class com.hazelcast.internal.config.DeclarativeConfigUtil
Checks if the suffix of the passed configFile is in the accepted suffixes list passed in acceptedSuffixes.
isAckNeeded(RaftEndpoint, int) - Method in class com.hazelcast.cp.internal.raft.impl.state.QueryState
 
isActive() - Method in class com.hazelcast.client.impl.spi.ClientContext
 
isActive(CPGroupId, long) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
isActive(CPGroupId, long) - Method in interface com.hazelcast.cp.internal.session.SessionAccessor
Checks if there is an active session with the given id in the Raft group
isActive() - Method in interface com.hazelcast.internal.nio.IOService
 
isActive() - Method in class com.hazelcast.internal.nio.NodeIOService
 
isActive() - Method in interface com.hazelcast.osgi.impl.HazelcastInternalOSGiService
Returns the state of the service about if it is active or not.
isActive() - Method in interface com.hazelcast.spi.impl.NodeEngine
Deprecated.
isActive() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
isAdvancedNetworkEnabled() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
isAfter(VectorClock) - Method in class com.hazelcast.cluster.impl.VectorClock
Returns true if this vector clock is causally strictly after the provided vector clock.
isAggregationQuery() - Method in class com.hazelcast.map.impl.query.Query
 
isAlive() - Method in interface com.hazelcast.client.impl.ClientEndpoint
Checks if the endpoint is alive.
isAlive() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
isAlive() - Method in interface com.hazelcast.client.impl.connection.ClientConnectionManager
Check if client connection manager is alive.
isAlive() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
isAlive() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
isAlive(Member, long) - Method in interface com.hazelcast.internal.cluster.fd.ClusterFailureDetector
Returns true if given member is considered as alive/available.
isAlive(Member, long) - Method in class com.hazelcast.internal.cluster.fd.DeadlineClusterFailureDetector
 
isAlive(long) - Method in interface com.hazelcast.internal.cluster.fd.FailureDetector
Returns true if the tracked member is considered as alive/available.
isAlive(Member, long) - Method in class com.hazelcast.internal.cluster.fd.PhiAccrualClusterFailureDetector
 
isAlive(long) - Method in class com.hazelcast.internal.cluster.fd.PhiAccrualFailureDetector
 
isAlive(E) - Method in class com.hazelcast.internal.cluster.fd.PingFailureDetector
 
isAlive() - Method in interface com.hazelcast.internal.nio.Connection
Checks if the Connection is alive.
isAlive() - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
isAlivePerIcmp(Member) - Method in class com.hazelcast.splitbrainprotection.impl.AbstractPingAwareSplitBrainProtectionFunction
 
isAllowUnsafe() - Method in class com.hazelcast.config.SerializationConfig
Unsafe, it is not public api of java.
isAny() - Method in class com.hazelcast.query.impl.getters.JsonPathCursor
 
isAppendRequestBackoffSet() - Method in class com.hazelcast.cp.internal.raft.impl.state.FollowerState
Returns whether leader is waiting for response of the last append request.
isArray() - Method in class com.hazelcast.internal.json.JsonArray
 
isArray() - Method in class com.hazelcast.internal.json.JsonValue
Detects whether this value represents a JSON array.
isArray() - Method in class com.hazelcast.query.impl.getters.JsonPathCursor
 
isArrayItem() - Method in class com.hazelcast.json.internal.JsonSchemaNameValue
 
isArrayType() - Method in enum com.hazelcast.nio.serialization.FieldType
 
isAssigned(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray12byteKeyImpl
 
isAssigned(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
isAssignedToMember() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
 
isAssignedToMember() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
 
isAssignedToPartition() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
 
isAssignedToPartition() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
 
isAsyncFillup() - Method in class com.hazelcast.config.ReplicatedMapConfig
True if the replicated map is available for reads before the initial replication is completed, false otherwise.
isAsyncStart() - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
Client instance creation won't block on HazelcastClient.newHazelcastClient() if this value is true
isAtLeast(JavaVersion) - Static method in enum com.hazelcast.internal.util.JavaVersion
Check if the current runtime version is at least the given version.
isAtMost(JavaVersion) - Static method in enum com.hazelcast.internal.util.JavaVersion
Check if the current runtime version is at most the given version.
isAttributeName(JsonPathCursor) - Method in class com.hazelcast.internal.serialization.impl.DataInputNavigableJsonAdapter
 
isAttributeName(JsonPathCursor) - Method in class com.hazelcast.internal.serialization.impl.NavigableJsonInputAdapter
This method verifies that the underlying input currently points to an attribute name of a Json object.
isAttributeName(JsonPathCursor) - Method in class com.hazelcast.internal.serialization.impl.StringNavigableJsonAdapter
 
isAuthenticated() - Method in interface com.hazelcast.client.impl.ClientEndpoint
 
isAuthenticated() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
isAuthenticationConfigured() - Method in class com.hazelcast.config.security.RealmConfig
 
isAutoRemoveStaleData() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Returns whether or not automatically removal of stale Hot Restart data is enabled.
isAvailableOrNextSequence(ObjectNamespace, int, long) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
 
isAvailableOrNextSequence(ObjectNamespace, int, long) - Method in interface com.hazelcast.internal.journal.EventJournal
Checks if the sequence is of an item that can be read immediately or is the sequence of the next item to be added into the event journal.
isAvailableOrNextSequence(ObjectNamespace, int, long) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
 
isBackup(RecordStore) - Method in class com.hazelcast.map.impl.eviction.EvictorImpl
 
isBackupAckToClientEnabled() - Method in class com.hazelcast.client.config.ClientConfig
Note that backup acks to client can be enabled only for smart client.
isBeginFrame() - Method in class com.hazelcast.client.impl.protocol.ClientMessage.Frame
 
isBetween(Version, Version) - Method in class com.hazelcast.version.Version
Checks if the version is between specified version (both ends inclusive)
isBigEndian() - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Tells whether this memory accessor is big- or little-endian.
isBinary() - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
 
isBinary() - Method in class com.hazelcast.config.MultiMapConfig
Checks if the MultiMap is in binary (serialized) form.
isBinary() - Method in enum com.hazelcast.internal.nio.ConnectionType
 
isBinary() - Method in class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
 
isBitSet(int, int) - Static method in class com.hazelcast.internal.nio.Bits
Returns true if n-th bit of the value is set, false otherwise
isBlacklisted(Address) - Method in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
isBlacklisted(Address) - Method in interface com.hazelcast.internal.cluster.Joiner
Checks if an address is blacklisted.
isBoolean() - Method in class com.hazelcast.internal.json.JsonValue
Detects whether this value represents a boolean value.
isCacheLocalEntries() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.NearCacheConfigHolder
 
isCacheLocalEntries() - Method in class com.hazelcast.config.NearCacheConfig
Checks if local entries are also cached in the Near Cache.
isCallTimedOut(Operation) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
isCallTimedOut(Operation) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Checks if this call is timed out.
IsCanceledOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
IsCanceledOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.IsCanceledOperation
 
IsCanceledOperation(ScheduledTaskHandler) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.IsCanceledOperation
 
isCancelled() - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
isCancelled() - Method in class com.hazelcast.client.impl.proxy.ClientScheduledFutureProxy
 
isCancelled() - Method in class com.hazelcast.scheduledexecutor.impl.DelegatingScheduledFutureStripper
 
isCancelled(String) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
isCancelled() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledFutureProxy
 
isCancelled() - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
isCancelled() - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
isCancelled() - Method in class com.hazelcast.topic.impl.reliable.MessageRunner
 
isCheckClassDefErrors() - Method in class com.hazelcast.config.SerializationConfig
Default value is true (enabled).
IScheduledExecutorService - Interface in com.hazelcast.scheduledexecutor
Distributed & durable implementation similar to, but not directly inherited ScheduledExecutorService.
IScheduledFuture<V> - Interface in com.hazelcast.scheduledexecutor
A delayed result-bearing action that can be cancelled.
isClaimingMastership() - Method in class com.hazelcast.internal.cluster.impl.TcpIpJoiner
 
isClassAvailable(ClassLoader, String) - Static method in class com.hazelcast.internal.nio.ClassLoaderUtil
 
isClassDefined(String) - Static method in class com.hazelcast.internal.nio.ClassLoaderUtil
Indicates whether or not the given class exists
isClient() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
isClient - Variable in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
isClient() - Method in interface com.hazelcast.internal.nio.Connection
Checks if it is a client connection.
isClient() - Method in enum com.hazelcast.internal.nio.ConnectionType
 
isClient() - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
isClientAllowed(Client) - Method in interface com.hazelcast.client.impl.ClientEngine
 
isClientAllowed(Client) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
isClientAllowed(Client) - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
isClientFailoverSupported() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
isClientFailoverSupported() - Method in interface com.hazelcast.instance.impl.NodeExtension
 
isClientMode() - Method in class com.hazelcast.internal.networking.AbstractChannel
 
isClientMode() - Method in interface com.hazelcast.internal.networking.Channel
Checks if this side is the Channel is in client mode or server mode.
isClosed() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
isClosed() - Method in class com.hazelcast.internal.networking.AbstractChannel
 
isClosed() - Method in interface com.hazelcast.internal.networking.Channel
Checks if this Channel is closed.
isClusterSafe() - Method in class com.hazelcast.client.impl.proxy.PartitionServiceProxy
 
isClusterSafe() - Method in class com.hazelcast.internal.jmx.PartitionServiceMBean
 
isClusterSafe() - Method in class com.hazelcast.internal.partition.PartitionServiceProxy
 
isClusterSafe() - Method in interface com.hazelcast.partition.PartitionService
Checks whether the cluster is in a safe state.
isClusterVersionEqualTo(Version) - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
isClusterVersionGreaterOrEqual(Version) - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
isClusterVersionGreaterThan(Version) - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
isClusterVersionLessOrEqual(Version) - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
isClusterVersionLessThan(Version) - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
isClusterVersionUnknown() - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
isClusterVersionUnknownOrGreaterOrEqual(Version) - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
isClusterVersionUnknownOrGreaterThan(Version) - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
isClusterVersionUnknownOrLessOrEqual(Version) - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
isClusterVersionUnknownOrLessThan(Version) - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
isCoalesce() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
isCoalesce() - Method in class com.hazelcast.config.QueryCacheConfig
Returns true if coalescing is is enabled, otherwise returns false.
isCoalesce() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
 
isCommandPrefix(String) - Method in class com.hazelcast.internal.nio.ascii.TextParsers
 
isCommit - Variable in class com.hazelcast.client.impl.protocol.codec.XATransactionFinalizeCodec.RequestParameters
If true, the transaction is committed else transaction is rolled back.
isCompatible(ConfigCheck) - Method in class com.hazelcast.internal.cluster.impl.ConfigCheck
Checks if two Hazelcast configurations are compatible.
isCompletedExceptionally() - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
isCompletedExceptionally() - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
isCompletedExceptionally() - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
isCompletedExceptionally() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationFuture
 
isConfigLocation(URI) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
 
isConfigPresent() - Method in class com.hazelcast.config.AbstractConfigLocator
 
isConfigurableService() - Method in class com.hazelcast.spi.impl.servicemanager.ServiceInfo
 
isConnected() - Method in class com.hazelcast.client.util.ClientStateListener
 
isConnected() - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
isConnected() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
Returns if this member is connected to the Wan publisher
isContainerEmpty(CachePartitionSegment) - Method in class com.hazelcast.cache.impl.eviction.CacheClearExpiredRecordsTask
 
isContainerEmpty(T) - Method in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
isContainerEmpty(PartitionContainer) - Method in class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
 
isCoreService() - Method in class com.hazelcast.spi.impl.servicemanager.ServiceInfo
 
isCpSubsystemEnabled() - Method in class com.hazelcast.cp.internal.RaftService
 
isDefaultClassLoader - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
isDefaultNamespace(String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
isDefaultsDisabled() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
isDefaultURI - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
isDestroyed() - Method in interface com.hazelcast.cache.ICache
Determines whether this Cache instance has been destroyed.
isDetected() - Method in class com.hazelcast.internal.util.ConcurrencyDetection
Checks if any concurrency is detected.
isDisablePerEntryInvalidationEvents() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
isDisablePerEntryInvalidationEvents() - Method in class com.hazelcast.config.CacheConfig
Returns invalidation events disabled status for per entry.
isDisablePerEntryInvalidationEvents() - Method in class com.hazelcast.config.CacheSimpleConfig
Returns invalidation events disabled status for per entry.
isDiscoveryCompleted() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Returns whether the CP discovery process is completed or not.
isDiscoveryCompleted() - Method in class com.hazelcast.cp.internal.RaftService
 
isDisruptive() - Method in class com.hazelcast.cp.internal.raft.impl.dto.VoteRequest
 
isDone() - Method in class com.hazelcast.client.impl.proxy.ClientScheduledFutureProxy
 
isDone() - Method in enum com.hazelcast.hotrestart.BackupTaskState
Returns true if the backup task completed (successfully or with failure)
isDone() - Method in class com.hazelcast.scheduledexecutor.impl.DelegatingScheduledFutureStripper
 
isDone(String) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
isDone() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledFutureProxy
 
isDone() - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
isDone() - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
isDone() - Method in class com.hazelcast.wan.ConsistencyCheckResult
 
IsDoneOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
IsDoneOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.IsDoneOperation
 
IsDoneOperation(ScheduledTaskHandler) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.IsDoneOperation
 
isDoubleRepresentable(Class) - Static method in class com.hazelcast.query.impl.Numbers
 
isDrainerGone() - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
 
isEchoFailFastOnStartup() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
ISemaphore - Interface in com.hazelcast.cp
ISemaphore is a fault-tolerant distributed alternative to the Semaphore.
isEmpty() - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
isEmpty() - Method in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
 
isEmpty() - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
isEmpty() - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
isEmpty() - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
isEmpty() - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
isEmpty() - Method in class com.hazelcast.client.impl.proxy.ClientSetProxy
 
isEmpty() - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
isEmpty() - Method in class com.hazelcast.cluster.impl.VectorClock
Returns true if this vector clock is empty (there are no logical timestamps for any replica).
isEmpty() - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
isEmpty() - Method in class com.hazelcast.config.ClassFilter
 
isEmpty() - Method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
 
isEmpty() - Method in class com.hazelcast.internal.dynamicconfig.AggregatingMap
 
isEmpty() - Method in class com.hazelcast.internal.json.JsonArray
Returns true if this array contains no elements.
isEmpty() - Method in class com.hazelcast.internal.json.JsonObject
Returns true if this object contains no members.
isEmpty() - Method in class com.hazelcast.internal.locksupport.operations.LockReplicationOperation
 
isEmpty() - Method in class com.hazelcast.internal.metrics.managementcenter.ConcurrentArrayRingbuffer
 
isEmpty() - Method in class com.hazelcast.internal.metrics.managementcenter.ConcurrentArrayRingbuffer.RingbufferSlice
 
isEmpty() - Method in class com.hazelcast.internal.util.collection.BiInt2ObjectMap
Is map empty or not.
isEmpty() - Method in class com.hazelcast.internal.util.collection.InflatableSet
 
isEmpty() - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
 
isEmpty() - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap.KeySet
 
isEmpty() - Method in class com.hazelcast.internal.util.collection.IntHashSet
 
isEmpty() - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
 
isEmpty() - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
 
isEmpty() - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
 
isEmpty() - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
 
isEmpty() - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap.KeySet
 
isEmpty() - Method in class com.hazelcast.internal.util.collection.LongHashSet
isEmpty() - Method in interface com.hazelcast.internal.util.collection.LongSet
 
isEmpty() - Method in class com.hazelcast.internal.util.collection.LongSetHsa
 
isEmpty() - Method in class com.hazelcast.internal.util.collection.MapDelegatingSet
isEmpty() - Method in class com.hazelcast.internal.util.collection.PartitionIdSet
 
isEmpty(Collection) - Static method in class com.hazelcast.internal.util.CollectionUtil
Returns true if the given collection is null or empty, otherwise returns false.
isEmpty() - Method in class com.hazelcast.internal.util.concurrent.MPSCQueue
 
isEmpty() - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
Returns true if this map contains no key-value mappings.
isEmpty() - Method in class com.hazelcast.internal.util.scheduler.SecondsBasedEntryTaskScheduler
Returns true if there are no scheduled entries.
isEmpty() - Method in interface com.hazelcast.map.BaseMap
Returns true if this map contains no entries.
isEmpty() - Method in interface com.hazelcast.map.impl.event.EntryEventDataCache
Indicate whether event data have been created and are cached in this cache or not.
isEmpty() - Method in class com.hazelcast.map.impl.MapEntries
 
isEmpty() - Method in class com.hazelcast.map.impl.query.QueryResult
 
isEmpty() - Method in interface com.hazelcast.map.impl.querycache.accumulator.Accumulator
Returns true if this accumulator contains no elements.
isEmpty() - Method in class com.hazelcast.map.impl.querycache.accumulator.BasicAccumulator
 
isEmpty() - Method in class com.hazelcast.map.impl.querycache.event.BatchEventData
 
isEmpty() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
isEmpty() - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordStore
 
isEmpty() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
isEmpty() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
isEmpty() - Method in interface com.hazelcast.map.impl.recordstore.Storage
 
isEmpty() - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
isEmpty() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
isEmpty() - Method in interface com.hazelcast.map.QueryCache
 
isEmpty() - Method in class com.hazelcast.query.impl.getters.ImmutableMultiResult
 
isEmpty() - Method in class com.hazelcast.query.impl.getters.MultiResult
 
isEmpty() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicationOperation
 
isEmpty() - Method in class com.hazelcast.replicatedmap.impl.PartitionContainer
 
isEmpty() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
isEmpty() - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
 
isEmpty() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
isEmpty() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
isEmpty() - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
 
isEmpty() - Method in interface com.hazelcast.ringbuffer.impl.Ringbuffer
Checks if the ringbuffer is empty.
isEmpty() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
 
isEmpty() - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of Map.isEmpty().
IsEmptyOperation - Class in com.hazelcast.collection.impl.queue.operations
check if queue is empty
IsEmptyOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.IsEmptyOperation
 
IsEmptyOperation(String) - Constructor for class com.hazelcast.collection.impl.queue.operations.IsEmptyOperation
 
IsEmptyOperation - Class in com.hazelcast.replicatedmap.impl.operation
 
IsEmptyOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.IsEmptyOperation
 
IsEmptyOperation(String) - Constructor for class com.hazelcast.replicatedmap.impl.operation.IsEmptyOperation
 
IsEmptyOperationFactory - Class in com.hazelcast.map.impl.operation
 
IsEmptyOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.IsEmptyOperationFactory
 
IsEmptyOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.IsEmptyOperationFactory
 
isEnableCompression() - Method in class com.hazelcast.config.SerializationConfig
Enables compression when default java serialization is used.
isEnabled() - Method in class com.hazelcast.client.config.ClientCloudConfig
 
isEnabled() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
isEnabled() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
isEnabled() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
isEnabled() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueueStoreConfigHolder
 
isEnabled() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.RingbufferStoreConfigHolder
 
isEnabled() - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
 
isEnabled() - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
Returns if this configuration is enabled.
isEnabled() - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
isEnabled() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Checks whether the given join mechanism is enabled.
isEnabled() - Method in class com.hazelcast.config.DiscoveryConfig
 
isEnabled() - Method in class com.hazelcast.config.EventJournalConfig
Returns if the event journal is enabled.
isEnabled() - Method in class com.hazelcast.config.HotRestartConfig
Returns whether hot restart enabled on related data structure.
isEnabled() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Returns whether hot restart enabled on this member.
isEnabled() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
isEnabled() - Method in class com.hazelcast.config.InterfacesConfig
 
isEnabled() - Method in class com.hazelcast.config.ManagementCenterConfig
true if management center is enabled, false if disabled.
isEnabled() - Method in class com.hazelcast.config.MapStoreConfig
Returns if this configuration is enabled
isEnabled() - Method in class com.hazelcast.config.MCMutualAuthConfig
Returns if this configuration is enabled.
isEnabled() - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
isEnabled() - Method in class com.hazelcast.config.MemcacheProtocolConfig
Returns if MEMCACHE protocol support is enabled.
isEnabled() - Method in class com.hazelcast.config.MerkleTreeConfig
Returns if the merkle tree is enabled.
isEnabled() - Method in class com.hazelcast.config.MetricsConfig
Returns if metrics collection is enabled.
isEnabled() - Method in class com.hazelcast.config.MulticastConfig
Check if the multicast discovery mechanism has been enabled.
isEnabled() - Method in class com.hazelcast.config.NativeMemoryConfig
Returns true if native memory allocation is enabled, false otherwise.
isEnabled() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
isEnabled() - Method in class com.hazelcast.config.PartitionGroupConfig
Checks if this PartitionGroupConfig is enabled.
isEnabled() - Method in class com.hazelcast.config.QueueStoreConfig
 
isEnabled() - Method in class com.hazelcast.config.RestApiConfig
Checks if REST API access is enabled.
isEnabled() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
isEnabled() - Method in class com.hazelcast.config.SecurityConfig
 
isEnabled() - Method in class com.hazelcast.config.ServiceConfig
 
isEnabled() - Method in class com.hazelcast.config.SocketInterceptorConfig
Returns if this configuration is enabled.
isEnabled() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
isEnabled() - Method in class com.hazelcast.config.SSLConfig
Returns if this configuration is enabled.
isEnabled() - Method in class com.hazelcast.config.TcpIpConfig
Checks if the Tcp/Ip join mechanism is enabled.
isEnabled() - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Returns true if User Code Deployment is enabled
isEnabled() - Method in interface com.hazelcast.cp.internal.persistence.CPPersistenceService
Returns if the CP state persistence is enabled or not.
isEnabled() - Method in class com.hazelcast.cp.internal.persistence.NopCPPersistenceService
 
isEnabled() - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
isEnabled() - Method in interface com.hazelcast.internal.hotrestart.InternalHotRestartService
Returns whether hot-restart is enabled or not.
isEnabled() - Method in class com.hazelcast.internal.hotrestart.NoopInternalHotRestartService
 
isEnabled(ProbeLevel) - Method in enum com.hazelcast.internal.metrics.ProbeLevel
Checks if the this ProbeLevel has a precedence equal or higher than the minimumLevel.
isEnabled() - Method in class com.hazelcast.ringbuffer.impl.RingbufferStoreWrapper
Is the ring buffer store enabled.
isEnabledAndNotEmpty() - Method in class com.hazelcast.config.RestApiConfig
Return true if the REST API is enabled and at least one REST endpoint group is allowed.
isEnabledAndNotEmpty() - Method in class com.hazelcast.config.RestServerEndpointConfig
Return true if the REST API is enabled and at least one REST endpoint group is allowed.
isEnabledByDefault() - Method in enum com.hazelcast.config.RestEndpointGroup
Returns if this group is enabled by default.
isEnableDefaults() - Method in class com.hazelcast.config.ServicesConfig
 
isEnableSharedObject() - Method in class com.hazelcast.config.SerializationConfig
Enables shared object when default java serialization is used.
isEndFrame() - Method in class com.hazelcast.client.impl.protocol.ClientMessage.Frame
 
isEnqueueNewEvents() - Method in enum com.hazelcast.config.WanPublisherState
Returns true if this state allows enqueueing new events, false otherwise.
isEnterprise() - Method in class com.hazelcast.instance.BuildInfo
 
isEqual(Object, Object, SerializationService) - Method in interface com.hazelcast.internal.util.comparators.ValueComparator
 
isEqual(Object) - Static method in interface com.hazelcast.internal.util.function.PredicateEx
isEqualNode(Node) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
isEquals(Object, Object) - Method in class com.hazelcast.map.impl.querycache.subscriber.record.DataQueryCacheRecordFactory
 
isEquals(Object, Object) - Method in class com.hazelcast.map.impl.querycache.subscriber.record.ObjectQueryCacheRecordFactory
 
isEquals(Object, Object) - Method in interface com.hazelcast.map.impl.querycache.subscriber.record.QueryCacheRecordFactory
 
isEqualTo(Version) - Method in class com.hazelcast.version.Version
 
ISet<E> - Interface in com.hazelcast.collection
Concurrent, distributed implementation of Set
isEventsEnabled() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
isEvictable() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
 
isEvictionEnabled() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
isEvictionRequired() - Method in class com.hazelcast.cache.impl.maxsize.impl.EntryCountCacheEvictionChecker
 
isEvictionRequired() - Method in interface com.hazelcast.internal.eviction.EvictionChecker
Checks the state to see if it has reached its maximum configured size EvictionConfig.MaxSizePolicy
isEvictionRequired() - Method in class com.hazelcast.internal.nearcache.impl.maxsize.EntryCountNearCacheEvictionChecker
 
isExistingTransaction(Object) - Method in class com.hazelcast.spring.transaction.HazelcastTransactionManager
 
isExpirable() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
isExpirable() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
 
isExpirable() - Method in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
isExpirable() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
isExpirable() - Method in class com.hazelcast.map.impl.recordstore.RecordStoreAdapter
 
isExpirable() - Method in interface com.hazelcast.map.impl.StoreAdapter
 
isExpired(long) - Method in class com.hazelcast.cp.internal.session.CPSessionInfo
 
isExpired(long) - Method in interface com.hazelcast.cp.session.CPSession
Returns true if the session expires before the given timestamp.
isExpired(E) - Method in interface com.hazelcast.internal.eviction.ExpirationChecker
Checks if the given Expirable entry is expired or not.
isExpired(Record, long, boolean) - Method in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
isExpired(R, long, boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Checks whether a record is expired or not.
isExpiredAt(long) - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
isExpiredAt(long, long) - Static method in class com.hazelcast.cache.impl.record.CacheRecordFactory
Determines whether the Cache Entry associated with this value will expire at the specified time.
isExpiredAt(long) - Method in interface com.hazelcast.internal.eviction.Expirable
Checks whether the expiration time is passed with respect to the provided time.
isExpiredAt(long) - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
isFailFastOnStartup() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
isFailOnIndeterminateOperationState() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns the value to determine if CP Subsystem API calls will fail when result of an API call becomes indeterminate.
isFailOnMaxBackoff() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
whether to fail when the max-backoff has reached or continue waiting max-backoff-millis at each iteration When on fail, client shuts down.
IsFailoverSupportedMessageTask - Class in com.hazelcast.client.impl.protocol.task
 
IsFailoverSupportedMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.IsFailoverSupportedMessageTask
 
isFalse() - Method in class com.hazelcast.internal.json.JsonValue
Detects whether this value represents the JSON literal false.
isFineEnabled() - Method in class com.hazelcast.logging.AbstractLogger
 
isFineEnabled() - Method in interface com.hazelcast.logging.ILogger
Checks if the Level.FINE level is enabled.
isFinestEnabled() - Method in class com.hazelcast.logging.AbstractLogger
 
isFinestEnabled() - Method in interface com.hazelcast.logging.ILogger
Checks if the Level.FINEST level is enabled.
isFlagRaised(int) - Method in class com.hazelcast.internal.nio.Packet
Returns true if any of the flags supplied in the argument are set.
isFlagSet(int, int) - Static method in class com.hazelcast.client.impl.protocol.ClientMessage
 
isFromInclusive() - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
 
isFromInclusive() - Method in class com.hazelcast.query.impl.predicates.BoundedRangePredicate
 
isFromInclusive() - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
 
isFromInclusive() - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
 
isFromInclusive() - Method in interface com.hazelcast.query.impl.predicates.RangePredicate
 
isFsync() - Method in class com.hazelcast.config.HotRestartConfig
Returns whether disk write should be followed by an fsync() system call.
isFullFlush() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore.Sequence
 
isGlobal() - Method in class com.hazelcast.query.impl.Indexes
 
isGlobalIndexEnabled() - Method in class com.hazelcast.map.impl.MapContainer
 
isGlobalOrderingEnabled() - Method in class com.hazelcast.config.TopicConfig
Checks if global ordering is enabled (all nodes listening to the same topic get their messages in the same order), or disabled (nodes get the messages in the order that the messages are published).
isGreaterOrEqual(Version) - Method in class com.hazelcast.version.Version
 
isGreaterThan(Version) - Method in class com.hazelcast.version.Version
 
isGreaterThanPivot(long) - Method in class com.hazelcast.internal.util.sort.IntMemArrayQuickSorter
 
isGreaterThanPivot(long) - Method in class com.hazelcast.internal.util.sort.LongMemArrayQuickSorter
 
isGreaterThanPivot(long) - Method in class com.hazelcast.internal.util.sort.QuickSorter
 
isGroupEnabled(RestEndpointGroup) - Method in class com.hazelcast.config.RestApiConfig
Checks if given REST endpoint group is enabled.
isGroupEnabled(RestEndpointGroup) - Method in class com.hazelcast.config.RestServerEndpointConfig
Checks if given REST endpoint group is enabled.
isHotBackupEnabled() - Method in interface com.hazelcast.hotrestart.HotRestartService
Returns if hot backup is enabled.
isHotBackupEnabled() - Method in class com.hazelcast.internal.hotrestart.NoOpHotRestartService
 
isHotBackupEnabled() - Method in interface com.hazelcast.monitor.HotRestartState
 
isHotBackupEnabled() - Method in class com.hazelcast.monitor.impl.HotRestartStateImpl
 
isIdentical(Member) - Method in class com.hazelcast.internal.partition.PartitionReplica
 
isIdentityConfigured() - Method in class com.hazelcast.config.security.RealmConfig
 
isIdleAt(long, long) - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
isIdleAt(long, long) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecord
Checks whether the maximum idle time is passed with respect to the provided time without any access during this time period as maxIdleSeconds.
isIncludeValue() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.ListenerConfigHolder
 
isIncludeValue() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
isIncludeValue() - Method in class com.hazelcast.collection.impl.collection.CollectionEventFilter
 
isIncludeValue() - Method in class com.hazelcast.collection.impl.queue.QueueEventFilter
 
isIncludeValue() - Method in class com.hazelcast.config.EntryListenerConfig
 
isIncludeValue() - Method in class com.hazelcast.config.ItemListenerConfig
 
isIncludeValue() - Method in class com.hazelcast.config.ListenerConfig
 
isIncludeValue() - Method in class com.hazelcast.config.QueryCacheConfig
Returns true if value caching enabled, otherwise returns false.
isIncludeValue() - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
 
isIncludeValue() - Method in class com.hazelcast.map.impl.EntryEventFilter
 
isIncludeValue() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
 
isIncludeValue() - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRequest
 
isIncludeValue() - Method in class com.hazelcast.multimap.impl.MultiMapEventFilter
 
isIndexed(QueryContext) - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
isIndexed(QueryContext) - Method in class com.hazelcast.query.impl.predicates.AbstractIndexAwarePredicate
 
isIndexed(QueryContext) - Method in class com.hazelcast.query.impl.predicates.AndPredicate
 
isIndexed(QueryContext) - Method in class com.hazelcast.query.impl.predicates.CompositeEqualPredicate
 
isIndexed(QueryContext) - Method in class com.hazelcast.query.impl.predicates.CompositeRangePredicate
 
isIndexed(QueryContext) - Method in class com.hazelcast.query.impl.predicates.FalsePredicate
 
isIndexed(QueryContext) - Method in interface com.hazelcast.query.impl.predicates.IndexAwarePredicate
Signals to the query engine that this predicate is able to utilize the indexes available while executing the query in the given query context.
isIndexed(QueryContext) - Method in class com.hazelcast.query.impl.predicates.OrPredicate
 
isIndexed(QueryContext) - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
Used if inner predicate is instanceof IndexAwarePredicate for checking if indexed.
isIndexed(QueryContext) - Method in class com.hazelcast.query.impl.predicates.SqlPredicate
 
isInfoEnabled() - Method in class com.hazelcast.logging.AbstractLogger
 
isInfoEnabled() - Method in interface com.hazelcast.logging.ILogger
Checks if the Level.INFO level is enabled.
isInitialized() - Method in class com.hazelcast.internal.partition.impl.PartitionStateManager
 
isInstanceOf(Class) - Method in class com.hazelcast.spi.impl.servicemanager.ServiceInfo
 
isInternalType(Class) - Static method in class com.hazelcast.internal.nio.ClassLoaderUtil
 
isInvalidateOnChange() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.NearCacheConfigHolder
 
isInvalidateOnChange() - Method in class com.hazelcast.config.NearCacheConfig
Checks if Near Cache entries are invalidated when the entries in the backing data structure are changed (updated or removed).
isInvalidationEnabled() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
isInvocationAllowed(Operation, boolean) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
isInvocationAllowed(Operation, boolean) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
Checks if the Operation is allowed to be invoked from the current thread.
isIpAddress(String) - Static method in class com.hazelcast.internal.util.AddressUtil
 
isIPv4() - Method in class com.hazelcast.cluster.Address
 
isIPv4() - Method in class com.hazelcast.internal.util.AddressUtil.AddressMatcher
 
isIPv6() - Method in class com.hazelcast.cluster.Address
 
isIPv6() - Method in class com.hazelcast.internal.util.AddressUtil.AddressMatcher
 
isJCacheAvailable(ClassLoader) - Static method in class com.hazelcast.cache.impl.JCacheDetector
 
isJCacheAvailable(ClassLoader, ILogger) - Static method in class com.hazelcast.cache.impl.JCacheDetector
 
isJDKCompatible() - Method in class com.hazelcast.config.cp.SemaphoreConfig
Returns true if CP ISemaphore is compatible with its JDK counterpart
isJmxEnabled() - Method in class com.hazelcast.config.MetricsConfig
Returns whether metrics will be exposed through JMX MBeans.
isJoinAllowed() - Method in enum com.hazelcast.cluster.ClusterState
Returns true, if joining of a new member is allowed in this state.
isJoined() - Method in interface com.hazelcast.internal.cluster.ClusterService
Returns whether this member joined to a cluster.
isJoined() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
isJoinOperation(Operation) - Static method in class com.hazelcast.spi.impl.operationservice.Operations
 
isJson() - Method in class com.hazelcast.internal.serialization.impl.HeapData
 
isJson() - Method in interface com.hazelcast.nio.serialization.Data
Returns true if this Data is created from a HazelcastJsonValue object, false otherwise
isKeepAlive() - Method in class com.hazelcast.client.config.SocketOptions
SO_KEEPALIVE socket option
isKeyAndValueLoadable(Data, Object) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
isKeyLoadFinished() - Method in class com.hazelcast.map.impl.MapKeyLoader
Returns true if there is no ongoing key loading and dispatching task on this map key loader.
isKeyLoadFinished() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
isKeyLoadFinished() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
IsKeyLoadFinishedOperation - Class in com.hazelcast.map.impl.operation
Returns if the key loading and dispatching has finished on this partition
IsKeyLoadFinishedOperation() - Constructor for class com.hazelcast.map.impl.operation.IsKeyLoadFinishedOperation
 
IsKeyLoadFinishedOperation(String) - Constructor for class com.hazelcast.map.impl.operation.IsKeyLoadFinishedOperation
 
isKnownMember(RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftGroupMembers
Returns true if the endpoint is a member of this group, false otherwise.
isKnownMember(RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns true if the endpoint is a member of the last applied group, false otherwise.
isKnownServiceNamespace(ServiceNamespace) - Method in class com.hazelcast.cache.impl.CacheService
 
isKnownServiceNamespace(ServiceNamespace) - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
isKnownServiceNamespace(ServiceNamespace) - Method in class com.hazelcast.map.impl.MapService
 
isKnownServiceNamespace(ServiceNamespace) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
isKnownServiceNamespace(ServiceNamespace) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
isKnownServiceNamespace(ServiceNamespace) - Method in class com.hazelcast.spi.impl.CountingMigrationAwareService
 
isKnownServiceNamespace(ServiceNamespace) - Method in interface com.hazelcast.spi.partition.FragmentedMigrationAwareService
Returns true if namespace is known by this service, false otherwise
isLaterThan(MembersView) - Method in class com.hazelcast.internal.cluster.impl.MembersView
 
isLeaseExpired() - Method in class com.hazelcast.internal.util.LockGuard
 
isLessOrEqual(Version) - Method in class com.hazelcast.version.Version
 
isLessThan(Version) - Method in class com.hazelcast.version.Version
 
isLessThanPivot(long) - Method in class com.hazelcast.internal.util.sort.IntMemArrayQuickSorter
 
isLessThanPivot(long) - Method in class com.hazelcast.internal.util.sort.LongMemArrayQuickSorter
 
isLessThanPivot(long) - Method in class com.hazelcast.internal.util.sort.QuickSorter
 
isLinearizableReadOptimizationEnabled() - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Returns true if the linearizable read optimization is enabled.
isLinearizableReadOptimizationEnabled() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Returns true if the linearizable read optimization is enabled.
isLinux() - Static method in class com.hazelcast.internal.util.OsHelper
Returns true if the system is Linux.
isListed(String) - Method in class com.hazelcast.config.ClassFilter
 
isListenerCancelled(UUID) - Method in class com.hazelcast.client.impl.proxy.ClientReliableTopicProxy
 
isLite() - Method in class com.hazelcast.internal.management.TimedMemberState
 
isLiteMember() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
isLiteMember() - Method in class com.hazelcast.cluster.impl.AbstractMember
 
isLiteMember() - Method in interface com.hazelcast.cluster.Member
Returns true if this member is a lite member.
isLiteMember() - Method in class com.hazelcast.config.Config
Returns true if this member is a lite member.
isLiteMember() - Method in class com.hazelcast.instance.impl.Node
 
isLiteMember() - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
 
isLiteMember() - Method in class com.hazelcast.internal.cluster.MemberInfo
 
isLiteMember() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
isLive() - Method in interface com.hazelcast.internal.nio.NetworkingService
Flag indicating the liveness status of the Network
isLive() - Method in class com.hazelcast.internal.nio.tcp.TcpIpNetworkingService
 
isLive() - Method in class com.hazelcast.internal.util.executor.StripedExecutor
Checks if this StripedExecutor is alive (so not shut down).
isLoaded() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
isLoaded() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Returns true if all key and value loading tasks have completed on this record store.
isLoaded - Variable in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
isLoaded() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
isLoaded() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
isLocal() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.ListenerConfigHolder
 
isLocal() - Method in class com.hazelcast.config.EntryListenerConfig
 
isLocal() - Method in class com.hazelcast.config.ListenerConfig
 
isLocal() - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
 
isLocal() - Method in interface com.hazelcast.internal.locksupport.LockResource
 
isLocal() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionImpl
 
isLocal() - Method in interface com.hazelcast.spi.partition.IPartition
Checks if the partition is local.
isLocalMemberSafe() - Method in class com.hazelcast.client.impl.proxy.PartitionServiceProxy
 
isLocalMemberSafe() - Method in class com.hazelcast.internal.jmx.PartitionServiceMBean
 
isLocalMemberSafe() - Method in class com.hazelcast.internal.partition.PartitionServiceProxy
 
isLocalMemberSafe() - Method in interface com.hazelcast.partition.PartitionService
Checks whether local member is in safe state.
isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapAddEntryListenerMessageTask
 
isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerMessageTask
 
isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyMessageTask
 
isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyWithPredicateMessageTask
 
isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerWithPredicateMessageTask
 
isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddNearCacheInvalidationListenerMessageTask
 
isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.map.Pre38MapAddNearCacheEntryListenerMessageTask
 
isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.multimap.AbstractMultiMapAddEntryListenerMessageTask
 
isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerMessageTask
 
isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerToKeyMessageTask
 
isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
 
isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
 
isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
 
isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
 
isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
 
isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
 
isLocalOnly() - Method in interface com.hazelcast.spi.impl.eventservice.EventRegistration
Returns true if this registration is for locally fired events only.
isLocalOnly() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
 
isLocked() - Method in class com.hazelcast.client.cp.internal.datastructures.lock.FencedLockProxy
 
isLocked(K) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
isLocked(K) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
isLocked() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockOwnershipState
 
isLocked() - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
isLocked() - Method in interface com.hazelcast.cp.lock.FencedLock
Returns whether this lock is locked or not.
isLocked(NodeEngine, Data) - Method in class com.hazelcast.internal.locksupport.LockProxySupport
 
isLocked() - Method in interface com.hazelcast.internal.locksupport.LockResource
 
isLocked(Data) - Method in interface com.hazelcast.internal.locksupport.LockStore
Check if a key is locked by any caller and thread ID.
isLocked(Data) - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
isLocked(Data) - Method in class com.hazelcast.internal.locksupport.LockStoreProxy
 
isLocked() - Method in class com.hazelcast.internal.util.LockGuard
 
isLocked(K) - Method in interface com.hazelcast.map.IMap
Checks the lock for the specified key.
isLocked() - Method in class com.hazelcast.map.impl.LockAwareLazyMapEntry
 
isLocked(K) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
isLocked(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
isLocked(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
isLocked() - Method in interface com.hazelcast.map.LockAware
 
isLocked(Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
isLocked(K) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
isLocked(K) - Method in interface com.hazelcast.multimap.MultiMap
Checks the lock for the specified key.
isLockedBy(long, long) - Method in class com.hazelcast.cp.internal.datastructures.lock.LockOwnershipState
 
isLockedBy(UUID, long) - Method in interface com.hazelcast.internal.locksupport.LockResource
 
isLockedBy(Data, UUID, long) - Method in interface com.hazelcast.internal.locksupport.LockStore
Check if a key is locked by a specific caller and thread ID.
isLockedBy(Data, UUID, long) - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
isLockedBy(Data, UUID, long) - Method in class com.hazelcast.internal.locksupport.LockStoreProxy
 
isLockedBy(Data, UUID, long) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
isLockedBy(Data, UUID, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
isLockedByCurrentThread() - Method in class com.hazelcast.client.cp.internal.datastructures.lock.FencedLockProxy
 
isLockedByCurrentThread() - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
isLockedByCurrentThread() - Method in interface com.hazelcast.cp.lock.FencedLock
Returns whether the lock is held by the current thread or not.
IsLockedOperation - Class in com.hazelcast.internal.locksupport.operations
 
IsLockedOperation() - Constructor for class com.hazelcast.internal.locksupport.operations.IsLockedOperation
 
IsLockedOperation(ObjectNamespace, Data) - Constructor for class com.hazelcast.internal.locksupport.operations.IsLockedOperation
 
IsLockedOperation(ObjectNamespace, Data, long) - Constructor for class com.hazelcast.internal.locksupport.operations.IsLockedOperation
 
isLoggable(Level) - Method in interface com.hazelcast.logging.ILogger
Checks if a message at the given level is going to be logged by this logger.
isLoggable(Level) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
isLongRepresentable(Class) - Static method in class com.hazelcast.query.impl.Numbers
 
isLoopbackModeEnabled() - Method in class com.hazelcast.config.MulticastConfig
Check if the loopback mode is enabled in the multicast discovery mechanism.
isLossTolerant() - Method in class com.hazelcast.topic.impl.reliable.ReliableMessageListenerAdapter
 
isLossTolerant() - Method in interface com.hazelcast.topic.ReliableMessageListener
Checks if this ReliableMessageListener is able to deal with message loss.
isMajorityAcked(long, int) - Method in class com.hazelcast.cp.internal.raft.impl.state.QueryState
Returns true if there are queries waiting and acks are received from the majority.
isMajorityGranted() - Method in class com.hazelcast.cp.internal.raft.impl.state.CandidateState
Returns true if majority of the votes are granted, false otherwise.
isManagedService() - Method in class com.hazelcast.spi.impl.servicemanager.ServiceInfo
 
isManagementEnabled() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
 
isManagementEnabled() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
isManagementEnabled - Variable in class com.hazelcast.config.AbstractCacheConfig
Whether management is enabled
isManagementEnabled() - Method in class com.hazelcast.config.AbstractCacheConfig
 
isManagementEnabled() - Method in class com.hazelcast.config.CacheSimpleConfig
Checks if management is enabled for this ICache.
isMapLoader() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
 
isMapLoader() - Method in class com.hazelcast.map.impl.MapStoreWrapper
 
isMapping(YamlNode) - Static method in class com.hazelcast.internal.yaml.YamlUtil
Checks if the provided node is a mapping
isMarkedAPMember() - Method in interface com.hazelcast.cp.internal.persistence.CPMetadataStore
Returns true if this member is marked as AP member on the storage layer.
isMarkedAPMember() - Method in class com.hazelcast.cp.internal.persistence.NopCPMetadataStore
 
isMaster() - Method in class com.hazelcast.instance.impl.Node
 
isMaster() - Method in interface com.hazelcast.internal.cluster.ClusterService
Checks if this member is the master.
isMaster() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
isMaster() - Method in class com.hazelcast.internal.management.TimedMemberState
 
isMaxIdleDefined(long) - Method in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
isMaxSizeReached() - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
 
isMcEnabled() - Method in class com.hazelcast.config.MetricsConfig
Returns whether metrics will be exposed to Hazelcast Management Center.
isMemberExcluded(Address, UUID) - Method in interface com.hazelcast.internal.hotrestart.InternalHotRestartService
Checks if the given member has been excluded during the cluster start or not.
isMemberExcluded(Address, UUID) - Method in class com.hazelcast.internal.hotrestart.NoopInternalHotRestartService
 
isMemberSafe(Member) - Method in class com.hazelcast.client.impl.proxy.PartitionServiceProxy
 
isMemberSafe(Member) - Method in class com.hazelcast.internal.partition.PartitionServiceProxy
 
isMemberSafe(Member) - Method in interface com.hazelcast.partition.PartitionService
Checks whether the given member is in safe state.
isMemberStateSafe() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
isMemberStateSafe() - Method in class com.hazelcast.monitor.impl.MemberPartitionStateImpl
 
isMemberStateSafe() - Method in interface com.hazelcast.monitor.MemberPartitionState
Returns whether member is safe for shutdown.
isMemberStateSafe() - Method in interface com.hazelcast.spi.partition.IPartitionService
Queries and returns if this member in a safe state or not.
isMergeable(C) - Method in class com.hazelcast.spi.impl.merge.AbstractContainerCollector
Determines if the container should be merged.
isMetricsForDataStructuresEnabled() - Method in class com.hazelcast.config.MetricsConfig
Returns if statistics for data structures are added to metrics.
isMigrating() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionImpl
 
isMigrating(int) - Method in class com.hazelcast.internal.partition.impl.PartitionStateManager
 
isMigrating() - Method in interface com.hazelcast.spi.partition.IPartition
Checks if there currently is a migration going on in this partition.
isMigrationAllowed() - Method in enum com.hazelcast.cluster.ClusterState
Returns true, if migrations and replications are allowed in this state.
isMigrationOperation(Operation) - Static method in class com.hazelcast.spi.impl.operationservice.Operations
 
isMinSizeReached() - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
 
isMissingMember(Address, UUID) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
Returns whether member with given identity (either UUID or Address depending on Hot Restart is enabled or not) is a known missing member or not.
isMissingPartitions() - Method in class com.hazelcast.internal.util.collection.PartitionIdSet
 
isModified() - Method in class com.hazelcast.map.impl.LazyMapEntry
 
isModified() - Method in class com.hazelcast.map.impl.MapEntrySimple
 
isMultiThreadingEnabled() - Method in class com.hazelcast.config.TopicConfig
Checks if multi-threaded processing of incoming messages is enabled or not.
isNearCacheEnabled() - Method in class com.hazelcast.config.MapConfig
Checks if Near Cache is enabled.
isNew() - Method in class com.hazelcast.internal.util.hashslot.impl.SlotAssignmentResultImpl
 
isNew() - Method in interface com.hazelcast.internal.util.hashslot.SlotAssignmentResult
 
isNextAvailableSequence(ObjectNamespace, int, long) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
 
isNextAvailableSequence(ObjectNamespace, int, long) - Method in interface com.hazelcast.internal.journal.EventJournal
Checks if the sequence is the sequence of the next event to be added to the event journal.
isNextAvailableSequence(ObjectNamespace, int, long) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
 
isNextEvent(Sequenced) - Method in class com.hazelcast.map.impl.querycache.subscriber.SubscriberAccumulator
 
isNodeVersionCompatibleWith(Version) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
isNodeVersionCompatibleWith(Version) - Method in interface com.hazelcast.instance.impl.NodeExtension
Check if this node's codebase version is compatible with given cluster version.
isNonInitial(SnapshotEntry) - Static method in class com.hazelcast.cp.internal.raft.impl.log.SnapshotEntry
 
isNot(String) - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
isNot(String) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
isNotEmpty(Collection) - Static method in class com.hazelcast.internal.util.CollectionUtil
Returns true if the given collection is not null and not empty, otherwise returns false.
isNotNull(E, String) - Static method in class com.hazelcast.internal.util.Preconditions
Tests if a string is not null.
isNotNull() - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
isNotNull() - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
isNull() - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
isNull() - Method in interface com.hazelcast.cp.IAtomicReference
Checks if the stored reference is null.
isNull() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
isNull() - Method in class com.hazelcast.internal.json.JsonValue
Detects whether this value represents the JSON literal null.
isNull() - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
isNull(Comparable) - Static method in class com.hazelcast.query.impl.predicates.PredicateUtils
 
isNull() - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
isNullAsync() - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
isNullAsync() - Method in interface com.hazelcast.cp.IAtomicReference
Checks if the stored reference is null.
isNullAsync() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
isNullEmptyTarget() - Method in class com.hazelcast.query.impl.getters.ImmutableMultiResult
 
isNullEmptyTarget() - Method in class com.hazelcast.query.impl.getters.MultiResult
 
isNullFrame() - Method in class com.hazelcast.client.impl.protocol.ClientMessage.Frame
 
isNullOrEmpty(Map) - Static method in class com.hazelcast.internal.util.MapUtil
Test the given map and return true if the map is null or empty.
isNullOrEmpty(String) - Static method in class com.hazelcast.internal.util.StringUtil
Checks if a string is empty or not.
isNullOrEmptyAfterTrim(String) - Static method in class com.hazelcast.internal.util.StringUtil
Checks if a string is empty or not after trim operation
isNumber() - Method in class com.hazelcast.internal.json.JsonValue
Detects whether this value represents a JSON number.
ISO_8859_1 - Static variable in class com.hazelcast.internal.nio.Bits
A reusable instance of the ISO Latin-1 charset
isObject() - Method in class com.hazelcast.internal.json.JsonObject
 
isObject() - Method in class com.hazelcast.internal.json.JsonValue
Detects whether this value represents a JSON object.
isObjectItem() - Method in class com.hazelcast.json.internal.JsonSchemaNameValue
 
isOfSameType(YamlNode, YamlNode) - Static method in class com.hazelcast.internal.yaml.YamlUtil
Checks if the two provided nodes are of the same type
isOfType(Class<T_SUGGESTED>) - Method in class com.hazelcast.internal.cluster.impl.ClusterStateChange
 
isOldValueAvailable() - Method in class com.hazelcast.cache.impl.CacheEntryEventImpl
 
isOldValueAvailable() - Method in class com.hazelcast.cache.impl.CacheEventContext
 
isOldValueAvailable() - Method in interface com.hazelcast.cache.impl.CacheEventData
Returns true if old value is available.
isOldValueAvailable() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
 
isOldValueRequired() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
If old value is required, previously assigned values for the affected keys will be sent to this cache entry listener implementation.
isOpen() - Method in class com.hazelcast.internal.networking.ServerSocketRegistry
 
isOrdered() - Method in class com.hazelcast.query.impl.AbstractIndex
 
isOrdered() - Method in interface com.hazelcast.query.impl.Index
Tells whether this index is ordered or not.
isOriginatedFromClient() - Method in class com.hazelcast.transaction.impl.SuspendedTransaction
 
isOriginatedFromClient() - Method in interface com.hazelcast.transaction.impl.Transaction
 
isOriginatedFromClient() - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
isOriginatedFromClient() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
 
isOverrideJavaSerialization() - Method in class com.hazelcast.config.GlobalSerializerConfig
 
isOverwritable() - Method in interface com.hazelcast.nio.serialization.SerializerHook
Defines if this serializer can be overridden by defining a custom serializer in the configurations (codebase or configuration file)
isOwnerOrBackup(Address) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionImpl
 
isOwnerOrBackup(PartitionReplica) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionImpl
 
isOwnerOrBackup(Address) - Method in interface com.hazelcast.spi.partition.IPartition
Checks if given address is owner of primary or backup of this partition.
isParallelMode() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
isParseDn() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
IsPartitionLoadedOperation - Class in com.hazelcast.map.impl.operation
 
IsPartitionLoadedOperation() - Constructor for class com.hazelcast.map.impl.operation.IsPartitionLoadedOperation
 
IsPartitionLoadedOperation(String) - Constructor for class com.hazelcast.map.impl.operation.IsPartitionLoadedOperation
 
IsPartitionLoadedOperationFactory - Class in com.hazelcast.map.impl.operation
 
IsPartitionLoadedOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.IsPartitionLoadedOperationFactory
 
IsPartitionLoadedOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.IsPartitionLoadedOperationFactory
 
isPartitionOwner(int) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
isPartitionOwner(int) - Method in interface com.hazelcast.spi.partition.IPartitionService
Check if this node is the owner of a partition.
isPartitionPromotionAllowed() - Method in enum com.hazelcast.cluster.ClusterState
Returns true, if partition promotions are allowed in this state.
isPartitionReplicaVersionDirty(int, ServiceNamespace) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
 
isPartitionReplicaVersionStale(int, ServiceNamespace, long[], int) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
 
isPartitionReplicaVersionStale(int, ServiceNamespace, long[], int) - Method in interface com.hazelcast.internal.partition.PartitionReplicaVersionManager
Returns whether given replica version is behind the current version or not.
isPersistenceEnabled(ObjectNamespace, int) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
 
isPersistenceEnabled() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Returns whether CP Subsystem Persistence enabled on this member.
isPersistenceEnabled(ObjectNamespace, int) - Method in interface com.hazelcast.internal.journal.EventJournal
Returns true if the event journal has persistence enabled and can be queried for events older than the EventJournal.oldestSequence(ObjectNamespace, int).
isPersistenceEnabled(ObjectNamespace, int) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
 
isPersistWanReplicatedData() - Method in class com.hazelcast.config.WanConsumerConfig
 
isPersistWanReplicatedData() - Method in class com.hazelcast.map.impl.MapContainer
 
isPollOperation() - Method in class com.hazelcast.collection.impl.txnqueue.TxQueueItem
 
isPopulate() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
isPopulate() - Method in class com.hazelcast.config.QueryCacheConfig
Returns true if initial population of QueryCache is enabled, otherwise returns false.
isPopulate() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
 
isPortable() - Method in class com.hazelcast.internal.serialization.impl.HeapData
 
isPortable() - Method in interface com.hazelcast.nio.serialization.Data
Returns true if this Data is created from a Portable object, false otherwise.
isPortAutoIncrement() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
isPortAutoIncrement() - Method in class com.hazelcast.config.NetworkConfig
Checks if a Hazelcast member is allowed find a free port by incrementing the port number when it encounters an occupied port.
isPortAutoIncrement() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
Checks if a Hazelcast member is allowed find a free port by incrementing the port number when it encounters an occupied port.
isPostProcessing(RecordStore) - Method in class com.hazelcast.map.impl.operation.MapOperation
 
isPostProcessingMapStore() - Method in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
 
isPostProcessingMapStore() - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
 
isPostProcessingMapStore() - Method in class com.hazelcast.map.impl.MapStoreWrapper
 
isPowerOfTwo(long) - Static method in class com.hazelcast.internal.util.QuickMath
Return true if input argument is power of two.
isPreCheckEnabled() - Method in class com.hazelcast.map.impl.query.QueryResultSizeLimiter
Just for testing.
isPreloadDone() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
isPreloadDone() - Method in interface com.hazelcast.internal.nearcache.NearCache
Checks if the pre-loading of the Near Cache is done.
isPresent() - Method in class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
Returns the presence of the split brain protection
isProjectionQuery() - Method in class com.hazelcast.map.impl.query.Query
 
isPublishable() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
 
isPutTransient() - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
 
isPutTransient() - Method in class com.hazelcast.map.impl.operation.PutTransientBackupOperation
 
isQueryResultLimitEnabled() - Method in class com.hazelcast.map.impl.query.QueryResultSizeLimiter
Just for testing.
isRaftGroupDestroyed(CPGroupId) - Method in class com.hazelcast.cp.internal.RaftService
 
isRawSocketPermitted() - Static method in class com.hazelcast.internal.util.ICMPHelper
 
isReachable(RaftEndpoint) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Returns true if the endpoint is reachable by the time this method is called, false otherwise.
isReadBackupData() - Method in class com.hazelcast.config.MapConfig
Checks if read-backup-data (reading local backup entries) is enabled for this map.
isReadThrough() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
isReadThrough() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
 
isReadThrough() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
isReadThrough - Variable in class com.hazelcast.config.AbstractCacheConfig
A flag indicating if "read-through" mode is required.
isReadThrough() - Method in class com.hazelcast.config.AbstractCacheConfig
 
isReadThrough() - Method in class com.hazelcast.config.CacheSimpleConfig
Checks if this ICache is read-through: a read loads the entry from the data store if it is not already in the cache.
isReady() - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Returns true if underlying platform is ready to operate, false otherwise.
isRecordExpired(R) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
isRedoOperation() - Method in class com.hazelcast.client.config.ClientNetworkConfig
isRedoOperation() - Method in interface com.hazelcast.client.impl.spi.ClientInvocationService
 
isRedoOperation() - Method in class com.hazelcast.client.impl.spi.impl.AbstractClientInvocationService
 
isReferenceAligned(long) - Static method in class com.hazelcast.internal.memory.impl.AlignmentUtil
 
isRegistered(String, String, boolean) - Static method in class com.hazelcast.cache.impl.MXBeanUtil
 
isRemove(long) - Static method in class com.hazelcast.collection.impl.CollectionTxnUtil
 
isRemoveOperation() - Method in class com.hazelcast.collection.impl.collection.TxCollectionItem
 
isRemoveOperation() - Method in interface com.hazelcast.collection.impl.txncollection.CollectionTxnOperation
 
isRemoveOperation() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
 
isRemoveOperation() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
 
isRemoveOperation() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
 
isRemoveOperation() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollOperation
 
isReplicateEnqueuedEvents() - Method in enum com.hazelcast.config.WanPublisherState
Returns true if this state allows dequeueing and replicating events, false otherwise.
isReply() - Method in class com.hazelcast.internal.cluster.impl.ExtendedBindMessage
 
isRepublishingEnabled() - Method in class com.hazelcast.config.WanReplicationRef
Returns true if incoming WAN events to this member should be republished (forwarded) to this WAN replication reference.
isResultDeserialized() - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Checks if the Future should automatically deserialize the result.
isRetryable() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.AddAndGetOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.GetAndAddOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.LocalGetOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.ContainsOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.GetOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.AwaitOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.CountDownOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.GetCountOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.GetRoundOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.GetLockOwnershipStateOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.LockOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.TryLockOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.UnlockOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.AcquirePermitsOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.AvailablePermitsOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.ChangePermitsOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.DrainPermitsOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.InitSemaphoreOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.ReleasePermitsOp
 
isRetryableOnIndeterminateOperationState() - Method in interface com.hazelcast.cp.internal.IndeterminateOperationStateAware
Returns true if duplicate commit of the operation is equivalent to committing it only once.
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.operation.ChangeRaftGroupMembershipOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.operation.DefaultRaftReplicateOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.operation.DestroyRaftGroupOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.operation.RaftQueryOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.raftop.GetInitialRaftGroupMembersIfCurrentGroupMemberOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.raftop.metadata.AddCPMemberOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.raftop.metadata.CompleteDestroyRaftGroupsOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.raftop.metadata.CompleteRaftGroupMembershipChangesOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.raftop.metadata.CreateRaftGroupOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.raftop.metadata.ForceDestroyRaftGroupOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetActiveCPMembersOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetActiveRaftGroupByNameOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetActiveRaftGroupIdsOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetDestroyingRaftGroupIdsOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetMembershipChangeScheduleOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetRaftGroupIdsOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.raftop.metadata.GetRaftGroupOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.raftop.metadata.InitMetadataRaftGroupOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.raftop.metadata.RemoveCPMemberOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.raftop.metadata.TriggerDestroyRaftGroupOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.session.operation.CloseInactiveSessionsOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.session.operation.CloseSessionOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.session.operation.CreateSessionOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.session.operation.ExpireSessionsOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.session.operation.GenerateThreadIdOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.session.operation.GetSessionsOp
 
isRetryableOnIndeterminateOperationState() - Method in class com.hazelcast.cp.internal.session.operation.HeartbeatSessionOp
 
isRetrySafeException(Throwable) - Static method in class com.hazelcast.client.impl.spi.impl.ClientInvocation
 
isReuseAddress() - Method in class com.hazelcast.client.config.SocketOptions
SO_REUSEADDR socket option.
isReuseAddress() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
isReuseAddress() - Method in class com.hazelcast.config.NetworkConfig
 
isReuseAddress() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
isRunAllowed(Operation) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
isRunAllowed(Operation) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
Checks if the Operation is allowed to run on the current thread.
isRunAllowed(Operation) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
isRunAllowed(Operation) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Returns true if the given operation is allowed to run on the calling thread, false otherwise.
isRunning() - Method in class com.hazelcast.client.impl.clientside.LifecycleServiceImpl
 
isRunning() - Method in interface com.hazelcast.core.LifecycleService
Checks whether or not the instance is running.
isRunning() - Method in class com.hazelcast.instance.impl.LifecycleServiceImpl
 
isRunning() - Method in class com.hazelcast.instance.impl.Node
Indicates that node is not shutting down or it has not already shut down
isRunning() - Method in class com.hazelcast.instance.impl.TerminatedLifecycleService
 
isRunning() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
isRunning() - Method in interface com.hazelcast.spi.impl.NodeEngine
Indicates that node is not shutting down or it has not already shut down
isRunning() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
isRunning() - Method in class com.hazelcast.wan.ConsistencyCheckResult
 
isSameGroup(ConfigCheck) - Method in class com.hazelcast.internal.cluster.impl.ConfigCheck
 
isSameNode(Node) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
isSameRM(XAResource) - Method in class com.hazelcast.client.impl.proxy.txn.xa.XAResourceProxy
 
isSameRM(XAResource) - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
 
isScalar(YamlNode) - Static method in class com.hazelcast.internal.yaml.YamlUtil
Checks if the provided node is a scalar
isScriptingEnabled() - Method in class com.hazelcast.config.ManagementCenterConfig
Returns if scripting is allowed (true) or disallowed (false).
isScriptingEnabled() - Method in class com.hazelcast.internal.management.TimedMemberState
 
isSequence(YamlNode) - Static method in class com.hazelcast.internal.yaml.YamlUtil
Checks if the provided node is a sequence
isSerializeKeys() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.NearCacheConfigHolder
 
isSerializeKeys() - Method in class com.hazelcast.config.NearCacheConfig
Checks if the Near Cache key is stored in serialized format or by-reference.
isSerializeKeys() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
isSerializeKeys() - Method in interface com.hazelcast.internal.nearcache.NearCache
Checks if the Near Cache key is stored in serialized format or by-reference.
isSevereEnabled() - Method in class com.hazelcast.logging.AbstractLogger
 
isSevereEnabled() - Method in interface com.hazelcast.logging.ILogger
Checks if the Level.SEVERE is enabled.
isShutdown() - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
isShutdown() - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
isShutdown() - Method in class com.hazelcast.client.impl.spi.impl.AbstractClientInvocationService
 
isShutdown() - Method in class com.hazelcast.client.util.ClientStateListener
 
isShutdown(String) - Method in class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
 
isShutdown() - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
isShutdown(String) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
 
isShutdown() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
isShutdown() - Method in class com.hazelcast.internal.jmx.ManagedExecutorServiceMBean
 
isShutdown() - Method in class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
isShutdown(String) - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
isSmartRouting() - Method in class com.hazelcast.client.config.ClientNetworkConfig
isSnapshotEnabled() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns true if key-based coalescing is configured for this WAN publisher.
isSocketBind() - Method in interface com.hazelcast.internal.nio.IOService
 
isSocketBind() - Method in class com.hazelcast.internal.nio.NodeIOService
 
isSocketBindAny() - Method in interface com.hazelcast.internal.nio.IOService
 
isSocketBindAny() - Method in class com.hazelcast.internal.nio.NodeIOService
 
isSocketBufferDirect() - Method in class com.hazelcast.config.EndpointConfig
 
isSocketInterceptorEnabled() - Method in class com.hazelcast.internal.management.TimedMemberState
 
isSocketInterceptorEnabled(EndpointQualifier) - Method in interface com.hazelcast.internal.nio.IOService
 
isSocketInterceptorEnabled(EndpointQualifier) - Method in class com.hazelcast.internal.nio.NodeIOService
 
isSocketKeepAlive() - Method in class com.hazelcast.config.EndpointConfig
 
isSocketTcpNoDelay() - Method in class com.hazelcast.config.EndpointConfig
 
isSslEnabled() - Method in class com.hazelcast.internal.management.TimedMemberState
 
isStale(long) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
isStale(long) - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
 
isStale(long) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
isStaleRead(Object, NearCacheRecord) - Method in interface com.hazelcast.internal.nearcache.impl.invalidation.StaleReadDetector
 
isStaleRead(Object, NearCacheRecord) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.StaleReadDetectorImpl
 
isStaleSequence(long) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
 
isStartCompleted() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
isStartCompleted() - Method in interface com.hazelcast.instance.impl.NodeExtension
Returns true if the instance has started
isStarted() - Method in class com.hazelcast.client.util.ClientStateListener
 
isStat - Variable in class com.hazelcast.client.impl.protocol.codec.CacheManagementConfigCodec.RequestParameters
true if enabling statistics, false if enabling management.
isStatisticsEnabled() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
isStatisticsEnabled() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
 
isStatisticsEnabled() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
isStatisticsEnabled - Variable in class com.hazelcast.config.AbstractCacheConfig
A flag indicating if statistics gathering is enabled.
isStatisticsEnabled() - Method in class com.hazelcast.config.AbstractCacheConfig
 
isStatisticsEnabled() - Method in class com.hazelcast.config.CacheSimpleConfig
Checks if statistics are enabled for this ICache.
isStatisticsEnabled() - Method in class com.hazelcast.config.CollectionConfig
Checks if collection statistics are enabled.
isStatisticsEnabled() - Method in class com.hazelcast.config.ExecutorConfig
Gets if statistics gathering is enabled or disabled on the executor task.
isStatisticsEnabled() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
isStatisticsEnabled() - Method in class com.hazelcast.config.MapConfig
Checks if statistics are enabled for this map.
isStatisticsEnabled() - Method in class com.hazelcast.config.MultiMapConfig
Checks to see if statistics are enabled for this MultiMap.
isStatisticsEnabled() - Method in class com.hazelcast.config.PNCounterConfig
Checks if statistics are enabled for this PN counter
isStatisticsEnabled() - Method in class com.hazelcast.config.QueueConfig
Check if statistics are enabled for this queue.
isStatisticsEnabled() - Method in class com.hazelcast.config.ReliableTopicConfig
Checks if statistics are enabled for this reliable topic.
isStatisticsEnabled() - Method in class com.hazelcast.config.ReplicatedMapConfig
Checks if statistics are enabled for this replicated map.
isStatisticsEnabled() - Method in class com.hazelcast.config.TopicConfig
Checks if statistics are enabled for this topic.
isStoreByValue() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
 
isStoreByValue() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
isStoreByValue - Variable in class com.hazelcast.config.AbstractCacheConfig
A flag indicating if the cache will be store-by-value or store-by-reference.
isStoreByValue() - Method in class com.hazelcast.config.AbstractCacheConfig
 
isString() - Method in class com.hazelcast.internal.json.JsonValue
Detects whether this value represents a JSON string.
isSuccess() - Method in class com.hazelcast.internal.partition.ReplicaMigrationEventImpl
 
isSuccess() - Method in interface com.hazelcast.partition.ReplicaMigrationEvent
Returns the result of the migration: completed or failed.
isSupported(OptionalFeature) - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
isSupported(OptionalFeature) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
 
isSupported(String, String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
isSynchronous() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
If true, this cache entry listener implementation will be called in a synchronous manner.
isTask() - Method in class com.hazelcast.durableexecutor.impl.TaskRingBuffer.DurableIterator
 
isTcpNoDelay() - Method in class com.hazelcast.client.config.SocketOptions
TCP_NODELAY socket option
isTerminal() - Method in class com.hazelcast.json.internal.JsonSchemaNode
Returns whether this node represents a scalar value.
isTerminal() - Method in class com.hazelcast.json.internal.JsonSchemaTerminalNode
 
isTerminal(Throwable) - Method in class com.hazelcast.topic.impl.reliable.ReliableMessageListenerAdapter
 
isTerminal(Throwable) - Method in interface com.hazelcast.topic.ReliableMessageListener
Checks if the ReliableMessageListener should be terminated based on an exception thrown while calling MessageListener.onMessage(Message).
isTerminated() - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
isTerminated() - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
isTerminated() - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
isTerminated() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
isTerminated() - Method in class com.hazelcast.internal.jmx.ManagedExecutorServiceMBean
 
isTerminated - Variable in class com.hazelcast.internal.management.dto.ManagedExecutorDTO
 
isTerminated() - Method in class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
isTerminatedOrSteppedDown() - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Returns true if this node is RaftNodeStatus.TERMINATED or RaftNodeStatus.STEPPED_DOWN, false otherwise.
isTerminatedOrSteppedDown() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
isToInclusive() - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
 
isToInclusive() - Method in class com.hazelcast.query.impl.predicates.BoundedRangePredicate
 
isToInclusive() - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
 
isToInclusive() - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
 
isToInclusive() - Method in interface com.hazelcast.query.impl.predicates.RangePredicate
 
isTombstone() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
isTooLargeSequence(long) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
 
isTransactional() - Method in interface com.hazelcast.internal.locksupport.LockResource
 
isTransactionallyLocked(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
isTransactionallyLocked(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
isTransactionallyLocked(Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
isTransient() - Method in class com.hazelcast.query.impl.CompositeConverter
 
isTrue() - Method in class com.hazelcast.internal.json.JsonValue
Detects whether this value represents the JSON literal true.
isTtlDefined(long) - Method in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
isTtlOrMaxIdleDefined(Record) - Method in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
isTtlOrMaxIdleDefined(Record) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Checks whether ttl or maxIdle are set on the record.
isTtlOrMaxIdleDefined(Record) - Method in class com.hazelcast.map.impl.recordstore.RecordStoreAdapter
 
isTtlOrMaxIdleDefined(R) - Method in interface com.hazelcast.map.impl.StoreAdapter
Checks whether ttl or maxIdle are set on the record.
isUnalignedAccessAllowed() - Static method in class com.hazelcast.internal.memory.impl.AlignmentUtil
 
isUnixFamily() - Static method in class com.hazelcast.internal.util.OsHelper
Returns true if the system is from Unix family.
isUnknown() - Method in class com.hazelcast.version.MemberVersion
 
isUnknown() - Method in class com.hazelcast.version.Version
 
isUnknownOrGreaterOrEqual(Version) - Method in class com.hazelcast.version.Version
 
isUnknownOrGreaterThan(Version) - Method in class com.hazelcast.version.Version
 
isUnknownOrLessOrEqual(Version) - Method in class com.hazelcast.version.Version
 
isUnknownOrLessThan(Version) - Method in class com.hazelcast.version.Version
 
isUrgent() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
isUrgent() - Method in class com.hazelcast.internal.ascii.AbstractTextCommand
 
isUrgent() - Method in interface com.hazelcast.internal.networking.OutboundFrame
Checks if this Frame is urgent.
isUrgent() - Method in class com.hazelcast.internal.nio.Packet
 
isUrgent() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
Check if this Response is an urgent response.
isUrgent() - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
isUseCachedDeserializedValuesEnabled(MapContainer, int) - Method in class com.hazelcast.map.impl.query.PartitionScanRunner
 
isUseEndpointPrivateAddress() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Returns whether the WAN connection manager should connect to the endpoint on the private address returned by the discovery SPI.
isUseNativeByteOrder() - Method in class com.hazelcast.config.SerializationConfig
 
isUsePublicIp() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Checks whether the public or private IP should be used to connect to Hazelcast members.
isValid() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
isValidForFetching(V, long) - Method in class com.hazelcast.internal.util.SampleableConcurrentHashMap
 
isValidForSampling(K, V) - Method in class com.hazelcast.internal.util.SampleableConcurrentHashMap
 
isWanReplicationEnabled() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
isWanReplicationEnabled(String) - Method in class com.hazelcast.cache.impl.CacheService
 
isWanReplicationEnabled() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Determines whether wan replication is enabled or not for this record store.
isWanReplicationEnabled(String) - Method in interface com.hazelcast.cache.impl.ICacheService
Returns true if WAN replication is enabled for the cache named cacheNameWithPrefix.
isWanReplicationEnabled() - Method in class com.hazelcast.map.impl.MapContainer
 
isWanReplicationOperation(Operation) - Static method in class com.hazelcast.spi.impl.operationservice.Operations
Checks if the given operation is an instance of WanReplicationOperation
isWanRepublishingEnabled() - Method in class com.hazelcast.map.impl.MapContainer
 
isWarningEnabled() - Method in class com.hazelcast.logging.AbstractLogger
 
isWarningEnabled() - Method in interface com.hazelcast.logging.ILogger
Checks if the Level.WARNING is enabled.
isWithExpirationTime() - Method in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
 
isWithExpirationTime() - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
 
isWithExpirationTime() - Method in class com.hazelcast.map.impl.MapStoreWrapper
 
isWriteBehindMapStoreEnabled() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
 
isWriteCoalescing() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
isWriteCoalescing() - Method in class com.hazelcast.config.MapStoreConfig
Returns true if write-coalescing is enabled.
isWriteThrough() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
isWriteThrough() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
 
isWriteThrough() - Method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
isWriteThrough - Variable in class com.hazelcast.config.AbstractCacheConfig
A flag indicating if "write-through" mode is required.
isWriteThrough() - Method in class com.hazelcast.config.AbstractCacheConfig
 
isWriteThrough() - Method in class com.hazelcast.config.CacheSimpleConfig
Checks if the ICache is write-through: a write to the queue also loads the entry into the data store.
item - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListAddCodec.RequestParameters
The new item added to the transactionalList
item - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListRemoveCodec.RequestParameters
Item to remove to transactional List
item - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueOfferCodec.RequestParameters
The element to add
item - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetAddCodec.RequestParameters
Item added to transactional set
item - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetRemoveCodec.RequestParameters
Item removed from Transactional Set
item - Variable in class com.hazelcast.collection.ItemEvent
 
ITEM_EVENT - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
 
ITEM_LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
itemAdded(ItemEvent) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
itemAdded(ItemEvent<E>) - Method in interface com.hazelcast.collection.ItemListener
Invoked when an item is added.
itemAdded(ItemEvent) - Method in class com.hazelcast.console.ConsoleApp
 
ItemCounter<T> - Class in com.hazelcast.internal.util
Non Thread-Safe Counter of things.
ItemCounter() - Constructor for class com.hazelcast.internal.util.ItemCounter
 
ItemEvent<E> - Class in com.hazelcast.collection
Event for a collection item.
ItemEvent(String, ItemEventType, E, Member) - Constructor for class com.hazelcast.collection.ItemEvent
 
ItemEventType - Enum in com.hazelcast.core
Type of item events.
itemId - Variable in class com.hazelcast.collection.impl.collection.CollectionItem
 
itemId - Variable in class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
 
itemId - Variable in class com.hazelcast.collection.impl.queue.QueueItem
 
itemIdSet - Variable in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
 
ItemListener<E> - Interface in com.hazelcast.collection
Item listener for IQueue, ISet and IList
ItemListenerConfig - Class in com.hazelcast.config
Contains the configuration for an Item Listener.
ItemListenerConfig() - Constructor for class com.hazelcast.config.ItemListenerConfig
 
ItemListenerConfig(String, boolean) - Constructor for class com.hazelcast.config.ItemListenerConfig
 
ItemListenerConfig(ItemListener, boolean) - Constructor for class com.hazelcast.config.ItemListenerConfig
 
ItemListenerConfig(ItemListenerConfig) - Constructor for class com.hazelcast.config.ItemListenerConfig
 
ItemListenerConfigReadOnly - Class in com.hazelcast.internal.config
Contains the configuration for an Item Listener(Read-only).
ItemListenerConfigReadOnly(ItemListenerConfig) - Constructor for class com.hazelcast.internal.config.ItemListenerConfigReadOnly
 
itemMap - Variable in class com.hazelcast.collection.impl.collection.CollectionContainer
 
itemRemoved(ItemEvent) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
itemRemoved(ItemEvent<E>) - Method in interface com.hazelcast.collection.ItemListener
Invoked when an item is removed.
itemRemoved(ItemEvent) - Method in class com.hazelcast.console.ConsoleApp
 
items - Variable in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalReadCodec.ResponseParameters
TODO DOC
items - Variable in class com.hazelcast.client.impl.protocol.codec.MapEventJournalReadCodec.ResponseParameters
TODO DOC
items - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferReadManyCodec.ResponseParameters
TODO DOC
items - Variable in class com.hazelcast.client.impl.protocol.codec.SetContainsAllCodec.RequestParameters
Collection to be checked for containment in this list
itemSeqs - Variable in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalReadCodec.ResponseParameters
TODO DOC
itemSeqs - Variable in class com.hazelcast.client.impl.protocol.codec.MapEventJournalReadCodec.ResponseParameters
TODO DOC
itemSeqs - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferReadManyCodec.ResponseParameters
TODO DOC
IterableUtil - Class in com.hazelcast.internal.util
Utility functions for working with Iterable
IterationType - Enum in com.hazelcast.internal.util
To differentiate users selection on result collection on map-wide operations like values, keySet, query etc.
iterationType(IterationType) - Method in class com.hazelcast.map.impl.query.Query.QueryBuilder
 
iterator() - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
iterator(int) - Method in interface com.hazelcast.cache.ICache
Creates and returns a cluster wide iterator to iterate on all entries owned by this cache.
iterator() - Method in class com.hazelcast.cache.impl.CacheProxy
 
iterator(int) - Method in class com.hazelcast.cache.impl.CacheProxy
 
iterator(int, int, boolean) - Method in class com.hazelcast.cache.impl.CacheProxy
 
iterator(int, int, boolean) - Method in interface com.hazelcast.cache.impl.ICacheInternal
Cluster-wide iterator for ICache
iterator() - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
iterator(int) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
iterator(int, int, boolean) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
iterator() - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
iterator(int, int, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
Returns an iterator for iterating entries in the partitionId.
iterator(int, int, Projection<? super Map.Entry<K, V>, R>, Predicate<K, V>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
Returns an iterator for iterating the result of the projection on entries in the partitionId which satisfy the predicate.
iterator() - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
iterator() - Method in class com.hazelcast.client.impl.proxy.ClientSetProxy
 
iterator() - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
iterator() - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
 
ITERATOR - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
iterator() - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
iterator() - Method in class com.hazelcast.durableexecutor.impl.TaskRingBuffer
 
iterator() - Method in class com.hazelcast.flakeidgen.impl.IdBatch
Returns iterator that will iterate contained IDs (boxing the as Long).
iterator() - Method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
 
iterator() - Method in class com.hazelcast.internal.json.JsonArray
Returns an iterator over the values of this array in document order.
iterator() - Method in class com.hazelcast.internal.json.JsonObject
Returns an iterator over the members of this object in document order.
iterator() - Method in class com.hazelcast.internal.networking.ServerSocketRegistry
 
iterator() - Method in class com.hazelcast.internal.util.collection.ImmutableInflatableSet
 
iterator() - Method in class com.hazelcast.internal.util.collection.InflatableSet
 
iterator() - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap.KeySet
 
iterator() - Method in class com.hazelcast.internal.util.collection.IntHashSet
 
iterator() - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap.KeySet
 
iterator() - Method in class com.hazelcast.internal.util.collection.LongHashSet
iterator() - Method in class com.hazelcast.internal.util.collection.MapDelegatingSet
iterator() - Method in class com.hazelcast.internal.util.collection.OAHashSet
 
iterator() - Method in class com.hazelcast.internal.util.collection.PartitionIdSet
 
iterator() - Method in class com.hazelcast.internal.util.concurrent.MPSCQueue
 
iterator() - Method in class com.hazelcast.internal.util.ResultSet
 
iterator(Class<T>, String, ClassLoader) - Static method in class com.hazelcast.internal.util.ServiceLoader
 
iterator(int, int, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
Returns an iterator for iterating entries in the partitionId.
iterator(int, int, Projection<? super Map.Entry<K, V>, R>, Predicate<K, V>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
Returns an iterator for iterating the result of the projection on entries in the partitionId which satisfy the predicate.
iterator() - Method in class com.hazelcast.map.impl.query.QueryResult
 
iterator() - Method in class com.hazelcast.map.impl.query.QueryResultCollection
 
iterator() - Method in interface com.hazelcast.map.impl.querycache.accumulator.Accumulator
Returns an iterator over the items in this accumulator in proper sequence.
iterator() - Method in class com.hazelcast.map.impl.querycache.accumulator.BasicAccumulator
 
iterator() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
iterator(long, boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
iterator() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Iterates over record store entries.
iterator(long, boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Iterates over record store entries by respecting expiration.
iterator() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
iterator() - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
iterator() - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
iterator() - Method in class com.hazelcast.query.impl.AndResultSet
 
iterator() - Method in class com.hazelcast.query.impl.DuplicateDetectingMultiResult
 
iterator() - Method in class com.hazelcast.query.impl.FastMultiResultSet
 
iterator() - Method in class com.hazelcast.query.impl.OrResultSet
 
iterator() - Method in class com.hazelcast.query.impl.SingleResultSet
 
iterator() - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
 
iterator() - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
 
iterator() - Method in class com.hazelcast.scheduledexecutor.impl.AbstractScheduledExecutorContainerHolder
 
iterator() - Method in class com.hazelcast.spi.impl.operationparker.impl.WaitSet
 
iterator() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
 
iterator() - Method in class com.hazelcast.spi.impl.SerializableList
 
iterator() - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
 
iterator() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Returns a read-only iterator.
IteratorOperation - Class in com.hazelcast.collection.impl.queue.operations
Provides iterator functionality for Queue.
IteratorOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.IteratorOperation
 
IteratorOperation(String) - Constructor for class com.hazelcast.collection.impl.queue.operations.IteratorOperation
 
ITopic<E> - Interface in com.hazelcast.topic
Hazelcast provides distribution mechanism for publishing messages that are delivered to multiple subscribers, which is also known as a publish/subscribe (pub/sub) messaging model.

J

JaasAuthenticationConfig - Class in com.hazelcast.config.security
This AuthenticationConfig implementation is a imple holder for login module configurations.
JaasAuthenticationConfig() - Constructor for class com.hazelcast.config.security.JaasAuthenticationConfig
 
JAVA - Static variable in class com.hazelcast.client.impl.ClientTypes
JVM clients protocol ID
JAVA_DEFAULT_TYPE_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_ARRAY_BLOCKING_QUEUE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_ARRAY_DEQUE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_ARRAY_LIST - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_BIG_DECIMAL - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_BIG_INTEGER - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_CLASS - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_CONCURRENT_HASH_MAP - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_CONCURRENT_SKIP_LIST_MAP - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_CONCURRENT_SKIP_LIST_SET - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_COPY_ON_WRITE_ARRAY_LIST - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_COPY_ON_WRITE_ARRAY_SET - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_DATE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_DELAY_QUEUE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_ENUM - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_EXTERNALIZABLE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_HASH_MAP - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_HASH_SET - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_LINKED_BLOCKING_QUEUE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_LINKED_HASH_MAP - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_LINKED_HASH_SET - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_LINKED_LIST - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_LINKED_TRANSFER_QUEUE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_PRIORITY_BLOCKING_QUEUE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_SERIALIZABLE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_SYNCHRONOUS_QUEUE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_TREE_MAP - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JAVA_DEFAULT_TYPE_TREE_SET - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JavaDefaultSerializers - Class in com.hazelcast.internal.serialization.impl
 
JavaDefaultSerializers.BigDecimalSerializer - Class in com.hazelcast.internal.serialization.impl
 
JavaDefaultSerializers.BigIntegerSerializer - Class in com.hazelcast.internal.serialization.impl
 
JavaDefaultSerializers.ClassSerializer - Class in com.hazelcast.internal.serialization.impl
 
JavaDefaultSerializers.DateSerializer - Class in com.hazelcast.internal.serialization.impl
 
JavaDefaultSerializers.EnumSerializer - Class in com.hazelcast.internal.serialization.impl
 
JavaDefaultSerializers.ExternalizableSerializer - Class in com.hazelcast.internal.serialization.impl
 
JavaDefaultSerializers.HazelcastJsonValueSerializer - Class in com.hazelcast.internal.serialization.impl
 
JavaDefaultSerializers.JavaSerializer - Class in com.hazelcast.internal.serialization.impl
 
javaExternalizableAdapter - Variable in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
JavaKeyStoreSecureStoreConfig - Class in com.hazelcast.config
Java KeyStore Secure Store configuration.
JavaKeyStoreSecureStoreConfig(File) - Constructor for class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Creates a new Java KeyStore Secure Store configuration.
JAVASCRIPT_JSON_SERIALIZATION_TYPE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JavaSerializationFilterConfig - Class in com.hazelcast.config
Configuration for Serialization Filter.
JavaSerializationFilterConfig() - Constructor for class com.hazelcast.config.JavaSerializationFilterConfig
 
JavaSerializationFilterConfig(JavaSerializationFilterConfig) - Constructor for class com.hazelcast.config.JavaSerializationFilterConfig
 
JavaSerializer(boolean, boolean, ClassNameFilter) - Constructor for class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.JavaSerializer
 
javaSerializerAdapter - Variable in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
JavaVersion - Enum in com.hazelcast.internal.util
Utility for checking runtime Java version.
JavaVm - Enum in com.hazelcast.internal.util
Utility for checking runtime Java VM.
JCACHE_PROVIDER_TYPE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Forces the JCache provider, which can have values client or server, to force the provider type.
JCacheDetector - Class in com.hazelcast.cache.impl
Utility class to detect existence of JCache 1.0.0 in the classpath.
JET_EXCEPTIONS_RANGE_END - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
JET_EXCEPTIONS_RANGE_START - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
JET_SERIALIZER_FIRST - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JET_SERIALIZER_LAST - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 
JetBuildInfo - Class in com.hazelcast.instance
 
JetBuildInfo(String, String, String) - Constructor for class com.hazelcast.instance.JetBuildInfo
 
JMX_UPDATE_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
JmxPublisher - Class in com.hazelcast.internal.metrics.jmx
Renderer to create, register and unregister mBeans for metrics as they are rendered.
JmxPublisher(String, String) - Constructor for class com.hazelcast.internal.metrics.jmx.JmxPublisher
 
join() - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
join() - Method in class com.hazelcast.client.impl.ClientInterceptingDelegatingFuture
 
join() - Method in class com.hazelcast.instance.impl.Node
 
join() - Method in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
join() - Method in interface com.hazelcast.internal.cluster.Joiner
 
join() - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
join() - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
join() - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
JOIN_MESSAGE - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
JOIN_REQUEST - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
JOIN_REQUEST_OP - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
JoinConfig - Class in com.hazelcast.config
Contains the 3 different join configurations; TCP-IP/multicast/AWS.
JoinConfig() - Constructor for class com.hazelcast.config.JoinConfig
 
Joiner - Interface in com.hazelcast.internal.cluster
 
joinInternal() - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
joinInternal() - Method in class com.hazelcast.client.impl.ClientInterceptingDelegatingFuture
 
joinInternal() - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
Similarly to AbstractInvocationFuture.join(), returns the value when complete or throws an unchecked exception if completed exceptionally.
joinInternal() - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
joinInternal() - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
joinInternal() - Method in class com.hazelcast.spi.impl.InternalCompletableFuture
Similarly to CompletableFuture.join(), returns the value when complete or throws an unchecked exception if completed exceptionally.
JoinMastershipClaimOp - Class in com.hazelcast.internal.cluster.impl.operations
 
JoinMastershipClaimOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.JoinMastershipClaimOp
 
JoinMessage - Class in com.hazelcast.internal.cluster.impl
 
JoinMessage() - Constructor for class com.hazelcast.internal.cluster.impl.JoinMessage
 
JoinMessage(byte, int, MemberVersion, Address, UUID, boolean, ConfigCheck) - Constructor for class com.hazelcast.internal.cluster.impl.JoinMessage
 
JoinMessage(byte, int, MemberVersion, Address, UUID, boolean, ConfigCheck, Collection<Address>, int) - Constructor for class com.hazelcast.internal.cluster.impl.JoinMessage
 
JoinOperation - Interface in com.hazelcast.internal.cluster.impl.operations
Marker interface for join and post-join operations.
JoinRequest - Class in com.hazelcast.internal.cluster.impl
 
JoinRequest() - Constructor for class com.hazelcast.internal.cluster.impl.JoinRequest
 
JoinRequest(byte, int, MemberVersion, Address, UUID, boolean, ConfigCheck, Credentials, Map<String, String>, Set<UUID>, Map<EndpointQualifier, Address>) - Constructor for class com.hazelcast.internal.cluster.impl.JoinRequest
 
JoinRequestOp - Class in com.hazelcast.internal.cluster.impl.operations
 
JoinRequestOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.JoinRequestOp
 
JoinRequestOp(JoinRequest) - Constructor for class com.hazelcast.internal.cluster.impl.operations.JoinRequestOp
 
Json - Class in com.hazelcast.internal.json
This class serves as the entry point to the minimal-json API.
JSON_COMMITTED_HEAP - Static variable in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
JSON_COMMITTED_NATIVE_MEMORY - Static variable in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
JSON_CREATION_TIME - Static variable in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
JSON_FREE_NATIVE_MEMORY - Static variable in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
JSON_FREE_PHYSICAL - Static variable in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
JSON_GC_STATS - Static variable in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
JSON_MAX_HEAP - Static variable in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
JSON_MAX_NATIVE_MEMORY - Static variable in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
JSON_TOTAL_PHYSICAL - Static variable in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
JSON_USED_HEAP - Static variable in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
JSON_USED_NATIVE_MEMORY - Static variable in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
JsonArray - Class in com.hazelcast.internal.json
Represents a JSON array, an ordered collection of JSON values.
JsonArray() - Constructor for class com.hazelcast.internal.json.JsonArray
Creates a new empty JsonArray.
JsonArray(JsonArray) - Constructor for class com.hazelcast.internal.json.JsonArray
Creates a new JsonArray with the contents of the specified JSON array.
JsonDataGetter - Class in com.hazelcast.query.impl.getters
 
JsonGetter - Class in com.hazelcast.query.impl.getters
 
JsonGetter() - Constructor for class com.hazelcast.query.impl.getters.JsonGetter
 
JsonGetterContext - Class in com.hazelcast.query.impl.getters
 
JsonGetterContext(String) - Constructor for class com.hazelcast.query.impl.getters.JsonGetterContext
 
JsonGetterContextCache - Class in com.hazelcast.query.impl.getters
 
JsonGetterContextCache(int, int) - Constructor for class com.hazelcast.query.impl.getters.JsonGetterContextCache
 
JsonHandler<A,O> - Class in com.hazelcast.internal.json
A handler for parser events.
JsonHandler() - Constructor for class com.hazelcast.internal.json.JsonHandler
 
JsonMetadataInitializer - Class in com.hazelcast.map.impl
 
JsonMetadataInitializer() - Constructor for class com.hazelcast.map.impl.JsonMetadataInitializer
 
JsonMetadataRecordStoreMutationObserver - Class in com.hazelcast.map.impl.recordstore
Creates json related metadata for map records.
JsonMetadataRecordStoreMutationObserver(InternalSerializationService, MetadataInitializer) - Constructor for class com.hazelcast.map.impl.recordstore.JsonMetadataRecordStoreMutationObserver
 
JsonObject - Class in com.hazelcast.internal.json
Represents a JSON object, a set of name/value pairs, where the names are strings and the values are JSON values.
JsonObject() - Constructor for class com.hazelcast.internal.json.JsonObject
Creates a new empty JsonObject.
JsonObject(JsonObject) - Constructor for class com.hazelcast.internal.json.JsonObject
Creates a new JsonObject, initialized with the contents of the specified JSON object.
JsonObject.Member - Class in com.hazelcast.internal.json
Represents a member of a JSON object, a pair of a name and a value.
JsonParser - Class in com.hazelcast.internal.json
A streaming parser for JSON text.
JsonParser(JsonHandler<?, ?>) - Constructor for class com.hazelcast.internal.json.JsonParser
Creates a new JsonParser with the given handler.
JsonPathCursor - Class in com.hazelcast.query.impl.getters
Represents a query path for Json querying.
JsonPattern - Class in com.hazelcast.json.internal
A JsonPattern is a structure that represents a logical path to a terminal value in a Json object.
JsonPattern() - Constructor for class com.hazelcast.json.internal.JsonPattern
Creates an empty JsonPattern.
JsonPattern(List<Integer>) - Constructor for class com.hazelcast.json.internal.JsonPattern
 
JsonPattern(JsonPattern) - Constructor for class com.hazelcast.json.internal.JsonPattern
Creates a deep copy of a JsonPattern
JsonReducedValueParser - Class in com.hazelcast.internal.json
A parser for a single JsonValue which is not an object or array.
JsonReducedValueParser() - Constructor for class com.hazelcast.internal.json.JsonReducedValueParser
 
JsonSchemaHelper - Class in com.hazelcast.json.internal
Responsible for creating and using JsonSchemaNodes.
JsonSchemaNameValue - Class in com.hazelcast.json.internal
A node that describes either a name-value pair in a Json object or an item in a Json array.
JsonSchemaNameValue(int, JsonSchemaNode) - Constructor for class com.hazelcast.json.internal.JsonSchemaNameValue
 
JsonSchemaNode - Class in com.hazelcast.json.internal
A node that describes either a JsonValue
JsonSchemaNode(JsonSchemaStructNode) - Constructor for class com.hazelcast.json.internal.JsonSchemaNode
Creates a schema node with given parent
JsonSchemaStructNode - Class in com.hazelcast.json.internal
A node that describes either a Json array or Json object.
JsonSchemaStructNode(JsonSchemaStructNode) - Constructor for class com.hazelcast.json.internal.JsonSchemaStructNode
 
JsonSchemaTerminalNode - Class in com.hazelcast.json.internal
Represents the description of a Json terminal value.
JsonSchemaTerminalNode(JsonSchemaStructNode) - Constructor for class com.hazelcast.json.internal.JsonSchemaTerminalNode
 
JsonSerializable - Interface in com.hazelcast.internal.management
JsonSerializable is a serialization interface that serializes/de-serializes to/from JSON.
JsonUtil - Class in com.hazelcast.internal.util
Utility class to deal with Json.
JsonValue - Class in com.hazelcast.internal.json
Represents a JSON value.
JVMUtil - Class in com.hazelcast.internal.util
Helper class for retrieving JVM specific information.

K

key - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
key - Variable in class com.hazelcast.cache.impl.operation.KeyBasedCacheOperation
 
key - Variable in class com.hazelcast.client.impl.protocol.codec.CacheContainsKeyCodec.RequestParameters
The key whose presence in this cache is to be tested.
key - Variable in class com.hazelcast.client.impl.protocol.codec.CacheEntryProcessorCodec.RequestParameters
the key to the entry
key - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAndRemoveCodec.RequestParameters
key with which the specified value is associated
key - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAndReplaceCodec.RequestParameters
The key whose value is replaced.
key - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetCodec.RequestParameters
The key whose mapped value is to be returned.
key - Variable in class com.hazelcast.client.impl.protocol.codec.CachePutCodec.RequestParameters
The key that has the specified value associated with it.
key - Variable in class com.hazelcast.client.impl.protocol.codec.CachePutIfAbsentCodec.RequestParameters
The key that is associated with the specified value.
key - Variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveCodec.RequestParameters
key whose mapping is to be removed from the cache
key - Variable in class com.hazelcast.client.impl.protocol.codec.CacheReplaceCodec.RequestParameters
The key whose value is replaced.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyWithPredicateCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapContainsKeyCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapDeleteCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapEvictCodec.RequestParameters
the specified key to evict from this map.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeyCodec.RequestParameters
the key of the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapForceUnlockCodec.RequestParameters
the key of the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapGetCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapGetEntryViewCodec.RequestParameters
the key of the entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapIsLockedCodec.RequestParameters
Key for the map entry to check if it is locked.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapLockCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentWithMaxIdleCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutTransientCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutTransientWithMaxIdleCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutWithMaxIdleCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveIfSameCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapReplaceCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapReplaceIfSameCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapSetCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapSetTtlCodec.RequestParameters
Key for the map entry
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapSetWithMaxIdleCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapSubmitToKeyCodec.RequestParameters
the key of the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapTryLockCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapTryPutCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapTryRemoveCodec.RequestParameters
Key for the map entry.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MapUnlockCodec.RequestParameters
Key for the map entry to unlock
key - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerToKeyCodec.RequestParameters
The key to listen to
key - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsEntryCodec.RequestParameters
The key whose existence is checked.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsKeyCodec.RequestParameters
The key whose existence is checked.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapDeleteCodec.RequestParameters
The key of the entry to remove
key - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapForceUnlockCodec.RequestParameters
The key to Lock
key - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapGetCodec.RequestParameters
The key whose associated values are to be returned
key - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapIsLockedCodec.RequestParameters
Key to lock to be checked.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapLockCodec.RequestParameters
The key the Lock
key - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapPutCodec.RequestParameters
The key to be stored
key - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveCodec.RequestParameters
The key of the entry to remove
key - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryCodec.RequestParameters
The key of the entry to remove
key - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapTryLockCodec.RequestParameters
Key to lock in this map.
key - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapUnlockCodec.RequestParameters
The key to Lock
key - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapValueCountCodec.RequestParameters
The key whose values count is to be returned
key - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyCodec.RequestParameters
Key with which the specified value is to be associated.
key - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyWithPredicateCodec.RequestParameters
Key with which the specified value is to be associated.
key - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsKeyCodec.RequestParameters
The key whose associated value is to be returned.
key - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapGetCodec.RequestParameters
The key whose associated value is to be returned
key - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutCodec.RequestParameters
Key with which the specified value is to be associated.
key - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveCodec.RequestParameters
Key with which the specified value is to be associated.
key - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsKeyCodec.RequestParameters
The specified key.
key - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapDeleteCodec.RequestParameters
Remove the mapping for this key.
key - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetCodec.RequestParameters
The specified key
key - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetForUpdateCodec.RequestParameters
The value to which the specified key is mapped
key - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutCodec.RequestParameters
The specified key
key - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutIfAbsentCodec.RequestParameters
The specified key
key - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveCodec.RequestParameters
Remove the mapping for this key.
key - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveIfSameCodec.RequestParameters
The specified key
key - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceCodec.RequestParameters
The specified key
key - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceIfSameCodec.RequestParameters
The specified key.
key - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSetCodec.RequestParameters
The specified key
key - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapGetCodec.RequestParameters
The key whose associated values are returned
key - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapPutCodec.RequestParameters
The key to be stored
key - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveCodec.RequestParameters
The key whose associated values are returned
key - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveEntryCodec.RequestParameters
The key whose associated values are returned
key - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapValueCountCodec.RequestParameters
The key whose number of values are returned
key() - Method in interface com.hazelcast.config.properties.PropertyDefinition
Returns the key (the name) of this property inside the configuration.
key() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
 
key - Variable in class com.hazelcast.core.EntryEvent
 
key() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKeyContainer
 
key - Variable in class com.hazelcast.internal.ascii.memcache.GetCommand
 
key - Variable in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
key() - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap.LongLongCursor
 
key() - Method in interface com.hazelcast.internal.util.collection.LongLongCursor
 
key - Variable in class com.hazelcast.internal.util.ConcurrentReferenceHashMap.SimpleEntry
 
key() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotCursor8byteKey
 
key() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase.Cursor
 
key - Variable in class com.hazelcast.internal.util.SampleableConcurrentHashMap.SamplingEntry
 
key - Variable in class com.hazelcast.map.impl.EntryEventFilter
 
key - Variable in class com.hazelcast.map.impl.record.AbstractRecord
 
key() - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
key() - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
key - Variable in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
 
key - Variable in class com.hazelcast.replicatedmap.impl.record.ReplicatedEntryEventFilter
 
key1() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotCursor12byteKey
 
key1() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotCursor16byteKey
 
key1() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase.Cursor
 
key1OfSlot(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
key2() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotCursor12byteKey
 
key2() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotCursor16byteKey
 
key2() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase.CursorIntKey2
 
key2() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase.CursorLongKey2
 
key2OfSlot(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray12byteKeyImpl
 
key2OfSlot(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray8byteKeyImpl
 
key2OfSlot(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
KEY_1_OFFSET - Static variable in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
KEY_2_OFFSET - Static variable in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
KEY_ITERATION_RESULT - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
KEY_ITERATOR - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
KEY_LOAD_STATUS - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
KEY_LOAD_STATUS_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
KEY_SET - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
KEY_SET - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
KEY_SET - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
keyAndRetries() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKeyContainer
 
KeyBasedCacheOperation - Class in com.hazelcast.cache.impl.operation
Operations running on a single key should extend this class.
KeyBasedCacheOperation() - Constructor for class com.hazelcast.cache.impl.operation.KeyBasedCacheOperation
 
KeyBasedCacheOperation(String, Data) - Constructor for class com.hazelcast.cache.impl.operation.KeyBasedCacheOperation
 
KeyBasedCacheOperation(String, Data, boolean) - Constructor for class com.hazelcast.cache.impl.operation.KeyBasedCacheOperation
 
KeyBasedMapOperation - Class in com.hazelcast.map.impl.operation
 
KeyBasedMapOperation() - Constructor for class com.hazelcast.map.impl.operation.KeyBasedMapOperation
 
KeyBasedMapOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.KeyBasedMapOperation
 
KeyBasedMapOperation(String, Data, Data) - Constructor for class com.hazelcast.map.impl.operation.KeyBasedMapOperation
 
keyData - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
keyData - Variable in class com.hazelcast.query.impl.CachedQueryEntry
 
keyHash(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray12byteKeyImpl
 
keyHash(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray8byteKeyImpl
 
keyHash(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
KeyIterator() - Constructor for class com.hazelcast.internal.util.collection.Int2ObjectHashMap.KeyIterator
 
KeyIterator() - Constructor for class com.hazelcast.internal.util.collection.Long2ObjectHashMap.KeyIterator
 
keyLoader - Variable in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
KeyLoadStatusOperation - Class in com.hazelcast.map.impl.operation
Notifies record store about completion of key loading.
KeyLoadStatusOperation() - Constructor for class com.hazelcast.map.impl.operation.KeyLoadStatusOperation
 
KeyLoadStatusOperation(String, Throwable) - Constructor for class com.hazelcast.map.impl.operation.KeyLoadStatusOperation
 
KeyLoadStatusOperationFactory - Class in com.hazelcast.map.impl.operation
KeyLoadStatusOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.KeyLoadStatusOperationFactory
 
KeyLoadStatusOperationFactory(String, Throwable) - Constructor for class com.hazelcast.map.impl.operation.KeyLoadStatusOperationFactory
 
keyObject - Variable in class com.hazelcast.query.impl.CachedQueryEntry
 
keys - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAllCodec.RequestParameters
The keys whose associated values are to be returned.
keys - Variable in class com.hazelcast.client.impl.protocol.codec.CacheIterateCodec.ResponseParameters
TODO DOC
keys - Variable in class com.hazelcast.client.impl.protocol.codec.CacheLoadAllCodec.RequestParameters
the keys to load
keys - Variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllKeysCodec.RequestParameters
The keys to remove.
keys - Variable in class com.hazelcast.client.impl.protocol.codec.CacheSetExpiryPolicyCodec.RequestParameters
The keys that are associated with the specified expiry policy.
keys - Variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeysCodec.RequestParameters
The keys for the entries for which the entry processor shall be executed on.
keys - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchKeysCodec.ResponseParameters
TODO DOC
keys - Variable in class com.hazelcast.client.impl.protocol.codec.MapGetAllCodec.RequestParameters
keys to get
keys - Variable in class com.hazelcast.client.impl.protocol.codec.MapLoadGivenKeysCodec.RequestParameters
keys to load
keys() - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
Returns an enumeration of the keys in this table.
keys - Variable in class com.hazelcast.map.impl.operation.MultipleEntryOperation
 
KEYS_WITH_CURSOR - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
keySet() - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
keySet(Predicate<K, V>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
keySet() - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
keySet() - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
keySet() - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
keySet(Predicate) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
keySet() - Method in class com.hazelcast.internal.dynamicconfig.AggregatingMap
 
keySet() - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
 
KeySet() - Constructor for class com.hazelcast.internal.util.collection.Int2ObjectHashMap.KeySet
 
keySet() - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
 
keySet() - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
 
KeySet() - Constructor for class com.hazelcast.internal.util.collection.Long2ObjectHashMap.KeySet
 
keySet() - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
Returns a Set view of the keys contained in this map.
keySet() - Method in class com.hazelcast.internal.util.ItemCounter
Returns an iterator over all keys.
keySet() - Method in interface com.hazelcast.map.BaseMap
Returns a set clone of the keys contained in this map.
keySet(Predicate<K, V>) - Method in interface com.hazelcast.map.BaseMap
Queries the map based on the specified predicate and returns the keys of matching entries.
keySet() - Method in interface com.hazelcast.map.IMap
Returns an immutable set clone of the keys contained in this map.
keySet(Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
Queries the map based on the specified predicate and returns an immutable Set clone of the keys of matching entries.
keySet() - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
keySet(Predicate<K, V>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
keySet() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
keySet(Predicate) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
keySet() - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordStore
 
keySet() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
keySet(Predicate) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
keySet() - Method in interface com.hazelcast.map.QueryCache
 
keySet(Predicate<K, V>) - Method in interface com.hazelcast.map.QueryCache
 
keySet() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
keySet() - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
keySet() - Method in interface com.hazelcast.multimap.MultiMap
Returns the set of keys in the multimap.
keySet(boolean) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
keySet() - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
 
keySet(boolean) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
keySet() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
keySet() - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Returns a lazy Set view of the key contained in this map.
A LazySet is optimized for querying speed (preventing eager deserialization and hashing on HashSet insertion) and does NOT provide all operations.
keySet() - Method in class com.hazelcast.spi.properties.HazelcastProperties
Returns an immutable set of all keys in this HazelcastProperties.
keySet() - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.keySet().
keySet(Predicate<K, V>) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.keySet(com.hazelcast.query.Predicate).
keySetInternal() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
KeySetOperation - Class in com.hazelcast.multimap.impl.operations
 
KeySetOperation() - Constructor for class com.hazelcast.multimap.impl.operations.KeySetOperation
 
KeySetOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.KeySetOperation
 
KeySetOperation - Class in com.hazelcast.replicatedmap.impl.operation
 
KeySetOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.KeySetOperation
 
KeySetOperation(String) - Constructor for class com.hazelcast.replicatedmap.impl.operation.KeySetOperation
 
keysFromIndex - Variable in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
 
keyType - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
class name of key type
keyValueTypesEqual(AbstractCacheConfig) - Method in class com.hazelcast.cache.impl.PreJoinCacheConfig
 
keyValueTypesEqual(AbstractCacheConfig) - Method in class com.hazelcast.config.AbstractCacheConfig
 
KILO_BYTE - Static variable in class com.hazelcast.client.config.SocketOptions
constant for kilobyte
KILO_BYTE - Static variable in interface com.hazelcast.internal.nio.IOService
 
kiloBytes() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in kilo-bytes.
KUBERNETES_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
KubernetesConfig - Class in com.hazelcast.config
Configuration for the Kubernetes Discovery Strategy.
KubernetesConfig() - Constructor for class com.hazelcast.config.KubernetesConfig
 
KubernetesConfig(KubernetesConfig) - Constructor for class com.hazelcast.config.KubernetesConfig
 

L

labels - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec.RequestParameters
User defined labels of the client instance
labels - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec.RequestParameters
User defined labels of the client instance
labels - Variable in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
 
labels - Variable in class com.hazelcast.internal.management.dto.ClientEndPointDTO
 
labelSelector(String) - Static method in class com.hazelcast.client.impl.ClientSelectors
Regular regex rules are applied.
LAST_ACCESS_TIME - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
LAST_UPDATE_TIME - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
lastAccessTime - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
lastAccessTime - Variable in class com.hazelcast.map.impl.record.RecordInfo
 
lastAppendEntriesTimestamp() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
lastApplied() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns the index of highest log entry applied to state machine
lastApplied(long) - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Updates the last applied index
lastApplied - Variable in class com.hazelcast.cp.internal.RaftNodeMetrics
 
lastGroupMembers() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns the last applied group members
lastHeartbeat(Member) - Method in interface com.hazelcast.internal.cluster.fd.ClusterFailureDetector
Returns the last heartbeat timestamp for a member.
lastHeartbeat(Member) - Method in class com.hazelcast.internal.cluster.fd.DeadlineClusterFailureDetector
 
lastHeartbeat() - Method in interface com.hazelcast.internal.cluster.fd.FailureDetector
Returns the last heartbeat timestamp for the tracked member.
lastHeartbeat(Member) - Method in class com.hazelcast.internal.cluster.fd.PhiAccrualClusterFailureDetector
 
lastHeartbeat() - Method in class com.hazelcast.internal.cluster.fd.PhiAccrualFailureDetector
 
lastIdleTimeNanos - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromAddressCodec.ResponseParameters
TODO DOC
lastIdleTimeNanos - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromPartitionCodec.ResponseParameters
TODO DOC
lastIndexOf(Object) - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
lastIndexOf(Object) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
 
lastIndexOf(String, char, int) - Static method in class com.hazelcast.internal.util.StringUtil
Like a String.lastIndexOf but without MIN_SUPPLEMENTARY_CODE_POINT handling
lastIndexOf(String, char) - Static method in class com.hazelcast.internal.util.StringUtil
Like a String.lastIndexOf but without MIN_SUPPLEMENTARY_CODE_POINT handling
lastLogIndex() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendSuccessResponse
 
lastLogIndex() - Method in class com.hazelcast.cp.internal.raft.impl.dto.PreVoteRequest
 
lastLogIndex() - Method in class com.hazelcast.cp.internal.raft.impl.dto.TriggerLeaderElection
 
lastLogIndex() - Method in class com.hazelcast.cp.internal.raft.impl.dto.VoteRequest
 
lastLogIndex - Variable in class com.hazelcast.cp.internal.RaftNodeMetrics
 
lastLogOrSnapshotEntry() - Method in class com.hazelcast.cp.internal.raft.impl.log.RaftLog
Returns the last entry in the Raft log, either from the last log entry or from the last snapshot if no logs are available.
lastLogOrSnapshotIndex() - Method in class com.hazelcast.cp.internal.raft.impl.log.RaftLog
Returns the last entry index in the Raft log, either from the last log entry or from the last snapshot if no logs are available.
lastLogOrSnapshotTerm() - Method in class com.hazelcast.cp.internal.raft.impl.log.RaftLog
Returns the last term in the Raft log, either from the last log entry or from the last snapshot if no logs are available.
lastLogTerm() - Method in class com.hazelcast.cp.internal.raft.impl.dto.PreVoteRequest
 
lastLogTerm() - Method in class com.hazelcast.cp.internal.raft.impl.dto.TriggerLeaderElection
 
lastLogTerm() - Method in class com.hazelcast.cp.internal.raft.impl.dto.VoteRequest
 
lastLogTerm - Variable in class com.hazelcast.cp.internal.RaftNodeMetrics
 
lastReadTimeMillis() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
lastReadTimeMillis() - Method in interface com.hazelcast.internal.networking.Channel
Returns the last time epoch time in ms a read of the socket was done.
lastReadTimeMillis() - Method in class com.hazelcast.internal.networking.nio.NioChannel
 
lastReadTimeMillis() - Method in class com.hazelcast.internal.networking.nio.NioInboundPipeline
 
lastReadTimeMillis() - Method in interface com.hazelcast.internal.nio.Connection
Returns the clock time in milliseconds of the most recent read using this connection.
lastReadTimeMillis() - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
lastRunDurationNanos - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromAddressCodec.ResponseParameters
TODO DOC
lastRunDurationNanos - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromPartitionCodec.ResponseParameters
TODO DOC
lastStoredTime - Variable in class com.hazelcast.map.impl.record.RecordInfo
 
lastTableIndex - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
The table is segment table of hash map, which is an array that stores the actual records.
lastTableIndex - Variable in class com.hazelcast.map.impl.iterator.AbstractMapPartitionIterator
The table is segment table of hash map, which is an array that stores the actual records.
lastTableIndex - Variable in class com.hazelcast.map.impl.iterator.AbstractMapQueryPartitionIterator
The table is segment table of hash map, which is an array that stores the actual records.
lastUpdateTime - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
lastUpdateTime - Variable in class com.hazelcast.map.impl.record.RecordInfo
 
lastWriteTimeMillis() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
lastWriteTimeMillis() - Method in interface com.hazelcast.internal.networking.Channel
Returns the last time epoch time in ms a write to the socket was done.
lastWriteTimeMillis() - Method in class com.hazelcast.internal.networking.nio.NioChannel
 
lastWriteTimeMillis() - Method in class com.hazelcast.internal.networking.nio.NioOutboundPipeline
 
lastWriteTimeMillis() - Method in interface com.hazelcast.internal.nio.Connection
Returns the clock time in milliseconds of the most recent write using this connection.
lastWriteTimeMillis() - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
LatencyTrackingCacheLoader<K,V> - Class in com.hazelcast.cache.impl
 
LatencyTrackingCacheLoader(CacheLoader<K, V>, StoreLatencyPlugin, String) - Constructor for class com.hazelcast.cache.impl.LatencyTrackingCacheLoader
 
LatencyTrackingCacheWriter<K,V> - Class in com.hazelcast.cache.impl
 
LatencyTrackingCacheWriter(CacheWriter<K, V>, StoreLatencyPlugin, String) - Constructor for class com.hazelcast.cache.impl.LatencyTrackingCacheWriter
 
LatencyTrackingMapLoader<K,V> - Class in com.hazelcast.map.impl
 
LatencyTrackingMapLoader(MapLoader<K, V>, StoreLatencyPlugin, String) - Constructor for class com.hazelcast.map.impl.LatencyTrackingMapLoader
 
LatencyTrackingMapStore<K,V> - Class in com.hazelcast.map.impl
 
LatencyTrackingMapStore(MapStore<K, V>, StoreLatencyPlugin, String) - Constructor for class com.hazelcast.map.impl.LatencyTrackingMapStore
 
LatencyTrackingQueueStore<T> - Class in com.hazelcast.collection.impl.queue
 
LatencyTrackingQueueStore(QueueStore<T>, StoreLatencyPlugin, String) - Constructor for class com.hazelcast.collection.impl.queue.LatencyTrackingQueueStore
 
LATEST_ACCESS - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
LATEST_UPDATE - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
LatestAccessMergePolicy<V,T extends MergingLastAccessTime<V>> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination data structure if the source entry has been accessed more recently than the destination entry.
LatestAccessMergePolicy() - Constructor for class com.hazelcast.spi.merge.LatestAccessMergePolicy
 
LatestUpdateMergePolicy<V,T extends MergingLastUpdateTime<V>> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination data structure if the source entry was updated more frequently than the destination entry.
LatestUpdateMergePolicy() - Constructor for class com.hazelcast.spi.merge.LatestUpdateMergePolicy
 
LAZY_MAP_ENTRY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
LazyCacheEntryView<K,V> - Class in com.hazelcast.cache.impl.merge.entry
An implementation of CacheEntryView for converting key and value to object when they are touched as lazy.
LazyCacheEntryView(Object, Object, long, long, long, long, Object) - Constructor for class com.hazelcast.cache.impl.merge.entry.LazyCacheEntryView
 
LazyCacheEntryView(Object, Object, long, long, long, long, Object, SerializationService) - Constructor for class com.hazelcast.cache.impl.merge.entry.LazyCacheEntryView
 
LazyDistributedObjectEvent - Class in com.hazelcast.client.impl.spi.impl.listener
 
LazyDistributedObjectEvent(DistributedObjectEvent.EventType, String, String, DistributedObject, ProxyManager) - Constructor for class com.hazelcast.client.impl.spi.impl.listener.LazyDistributedObjectEvent
Constructs a DistributedObject Event.
LazyEntryViewFromRecord<R extends Record> - Class in com.hazelcast.map.impl.recordstore
Internally used EntryView implementation for sampling based eviction specific purposes.
LazyEntryViewFromRecord(R, SerializationService) - Constructor for class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
 
LazyMapEntry<K,V> - Class in com.hazelcast.map.impl
A Map.Entry implementation which serializes/de-serializes key and value objects on demand.
LazyMapEntry() - Constructor for class com.hazelcast.map.impl.LazyMapEntry
 
LazyMapEntry(Data, Object, InternalSerializationService) - Constructor for class com.hazelcast.map.impl.LazyMapEntry
 
LazyMapEntry(Data, Object, InternalSerializationService, Extractors) - Constructor for class com.hazelcast.map.impl.LazyMapEntry
 
LdapAuthenticationConfig - Class in com.hazelcast.config.security
Typed authentication configuration for BasicLdapLoginModule and LdapLoginModule.
LdapAuthenticationConfig() - Constructor for class com.hazelcast.config.security.LdapAuthenticationConfig
 
LdapRoleMappingMode - Enum in com.hazelcast.config.security
Enum for LDAP role mapping modes.
LdapSearchScope - Enum in com.hazelcast.config.security
Search scope types for LDAP queries.
leader() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendRequest
 
leader() - Method in class com.hazelcast.cp.internal.raft.impl.dto.InstallSnapshot
 
leader() - Method in class com.hazelcast.cp.internal.raft.impl.dto.TriggerLeaderElection
 
leader(RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Updates the known leader endpoint and calls RaftIntegration.onNodeStatusChange(RaftNodeStatus).
leader() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns the known leader
leader(RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Updates the known leader
LEADER_DEMOTED_EXCEPTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
leaderCommitIndex() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendRequest
 
LeaderDemotedException - Exception in com.hazelcast.cp.exception
A CPSubsystemException which is thrown when an appended but not-committed entry is truncated by the new leader.
LeaderDemotedException(RaftEndpoint, RaftEndpoint) - Constructor for exception com.hazelcast.cp.exception.LeaderDemotedException
 
LeaderElectionTask - Class in com.hazelcast.cp.internal.raft.impl.task
LeaderElectionTask is scheduled when current leader is null, unreachable or unknown by PreVoteResponseHandlerTask after a follower receives votes from at least majority.
LeaderElectionTask(RaftNodeImpl, boolean) - Constructor for class com.hazelcast.cp.internal.raft.impl.task.LeaderElectionTask
 
LeaderElectionTimeoutTask - Class in com.hazelcast.cp.internal.raft.impl.task
LeaderElectionTimeoutTask is scheduled by LeaderElectionTask to trigger leader election again if one is not elected after leader election timeout.
LeadershipTransferState - Class in com.hazelcast.cp.internal.raft.impl.state
State maintained by the leader of the Raft group during the leadership transfer process.
leadershipTransferState() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns the leadership transfer state
LeadershipTransferTask - Class in com.hazelcast.cp.internal.raft.impl.task
Sends a TriggerLeaderElection request to the endpoint given in LeadershipTransferState.endpoint().
LeaderState - Class in com.hazelcast.cp.internal.raft.impl.state
Mutable state maintained by the leader of the Raft group.
leaderState() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns the leader state
lease - Variable in class com.hazelcast.client.impl.protocol.codec.MapTryLockCodec.RequestParameters
time in milliseconds to wait before releasing the lock.
lease - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapTryLockCodec.RequestParameters
Time in milliseconds to wait before releasing the lock.
leaseTime - Variable in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
LEGACY_URI_ADD_WAN_CONFIG - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
LEGACY_URI_MANCENTER_WAN_CLEAR_QUEUES - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
LEGACY_URI_WAN_SYNC_ALL_MAPS - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
LEGACY_URI_WAN_SYNC_MAP - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
LEN - Static variable in class com.hazelcast.internal.ascii.TextProtocolsDataSerializerHook
 
LEN - Static variable in class com.hazelcast.internal.usercodedeployment.impl.UserCodeDeploymentSerializerHook
 
LEN - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
length() - Method in interface com.hazelcast.security.Parameters
 
lessEqual(Comparable) - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
lessEqual(Comparable) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
lessEqual(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a less than or equal to predicate that will pass items if the value stored under the given item attribute is less than or equal to the given value.
lessThan(Comparable) - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
lessThan(Comparable) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
lessThan(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a less than predicate that will pass items if the value stored under the given item attribute is less than the given value.
level() - Method in interface com.hazelcast.internal.auditlog.AuditableEvent
 
level(Level) - Method in interface com.hazelcast.internal.auditlog.EventBuilder
Sets the event Level.
level(Level) - Method in class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService.Builder
 
level() - Method in class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService.NoOpEvent
 
Level - Enum in com.hazelcast.internal.auditlog
Event importance levels.
LFU_EVICTION_POLICY - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
LFUEvictionPolicy - Class in com.hazelcast.map.eviction
LFU eviction policy for an IMap
LFUEvictionPolicy() - Constructor for class com.hazelcast.map.eviction.LFUEvictionPolicy
 
LFUEvictionPolicyComparator - Class in com.hazelcast.internal.eviction.impl.comparator
LFUEvictionPolicyComparator() - Constructor for class com.hazelcast.internal.eviction.impl.comparator.LFUEvictionPolicyComparator
 
LifecycleEvent - Class in com.hazelcast.core
Lifecycle events are fired when the HazelcastInstance state changes.
LifecycleEvent(LifecycleEvent.LifecycleState) - Constructor for class com.hazelcast.core.LifecycleEvent
 
LifecycleEvent.LifecycleState - Enum in com.hazelcast.core
Lifecycle states
LifecycleListener - Interface in com.hazelcast.core
Listener object for listening to lifecycle events of the Hazelcast instance
LifecycleService - Interface in com.hazelcast.core
LifecycleService allows you to shutdown, terminate, and listen to LifecycleEvents on HazelcastInstance.
LifecycleServiceImpl - Class in com.hazelcast.client.impl.clientside
Default LifecycleService implementation for the client.
LifecycleServiceImpl(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.impl.clientside.LifecycleServiceImpl
 
LifecycleServiceImpl - Class in com.hazelcast.instance.impl
 
LifecycleServiceImpl(HazelcastInstanceImpl) - Constructor for class com.hazelcast.instance.impl.LifecycleServiceImpl
 
like(String, String) - Static method in class com.hazelcast.query.Predicates
Creates a like predicate that will pass items if the given pattern matches the value stored under the given item attribute.
LIKE_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
LikePredicate - Class in com.hazelcast.query.impl.predicates
Like Predicate
LikePredicate() - Constructor for class com.hazelcast.query.impl.predicates.LikePredicate
 
LikePredicate(String, String) - Constructor for class com.hazelcast.query.impl.predicates.LikePredicate
 
limit(Iterator<R>, int) - Static method in class com.hazelcast.internal.util.IterableUtil
 
line - Variable in class com.hazelcast.internal.json.Location
The line number, starting at 1.
LINE_SEPARATOR - Static variable in class com.hazelcast.internal.util.StringUtil
Points to the System property 'line.separator'.
LineReader - Interface in com.hazelcast.console
Reads a line of input.
LinkedBlockingQueueStreamSerializer<E> - Class in com.hazelcast.internal.serialization.impl
The LinkedBlockingQueue serializer
LinkedBlockingQueueStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.LinkedBlockingQueueStreamSerializer
 
LinkedHashMapStreamSerializer<K,V> - Class in com.hazelcast.internal.serialization.impl
The LinkedHashMap serializer Important Note: The ConcurrentHashMap 'loadfactor' is not serialized.
LinkedHashMapStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.LinkedHashMapStreamSerializer
 
LinkedHashSetStreamSerializer<E> - Class in com.hazelcast.internal.serialization.impl
The LinkedHashSet serializer Important Note: The LinkedHashSet 'loadfactor' is not serialized.
LinkedHashSetStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.LinkedHashSetStreamSerializer
 
LinkedListStreamSerializer<E> - Class in com.hazelcast.internal.serialization.impl
The LinkedList serializer
LinkedListStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.LinkedListStreamSerializer
 
LinkedTransferQueueStreamSerializer<E> - Class in com.hazelcast.internal.serialization.impl
The LinkedTransferQueue serializer
LinkedTransferQueueStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.LinkedTransferQueueStreamSerializer
 
LIST_ADD - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
LIST_ADD_ALL - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
LIST_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
LIST_CONTAINER - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
LIST_GET - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
LIST_INDEX_OF - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
LIST_REMOVE - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
LIST_REPLICATION - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
LIST_SET - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
LIST_SET_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
LIST_SUB - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
ListAddAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Appends all of the elements in the specified collection to the end of this list, in the order that they are returned by the specified collection's iterator (optional operation).
ListAddAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListAddAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListAddAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_ADDALL
ListAddAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListAddAllMessageTask
 
ListAddAllOperation - Class in com.hazelcast.collection.impl.list.operations
 
ListAddAllOperation() - Constructor for class com.hazelcast.collection.impl.list.operations.ListAddAllOperation
 
ListAddAllOperation(String, int, List<Data>) - Constructor for class com.hazelcast.collection.impl.list.operations.ListAddAllOperation
 
ListAddAllWithIndexCodec - Class in com.hazelcast.client.impl.protocol.codec
Inserts all of the elements in the specified collection into this list at the specified position (optional operation).
ListAddAllWithIndexCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListAddAllWithIndexCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListAddAllWithIndexMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_ADDALLWITHINDEX
ListAddAllWithIndexMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListAddAllWithIndexMessageTask
 
ListAddCodec - Class in com.hazelcast.client.impl.protocol.codec
Appends the specified element to the end of this list (optional operation).
ListAddCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListAddCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListAddListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds an item listener for this collection.
ListAddListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
ListAddListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListAddListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListAddListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
 
ListAddListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListAddListenerMessageTask
 
ListAddMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_ADD
ListAddMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListAddMessageTask
 
ListAddOperation - Class in com.hazelcast.collection.impl.list.operations
 
ListAddOperation() - Constructor for class com.hazelcast.collection.impl.list.operations.ListAddOperation
 
ListAddOperation(String, int, Data) - Constructor for class com.hazelcast.collection.impl.list.operations.ListAddOperation
 
ListAddWithIndexCodec - Class in com.hazelcast.client.impl.protocol.codec
Inserts the specified element at the specified position in this list (optional operation).
ListAddWithIndexCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListAddWithIndexCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListAddWithIndexMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_ADDWITHINDEX
ListAddWithIndexMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListAddWithIndexMessageTask
 
listAllNearCaches() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
 
listAllNearCaches() - Method in interface com.hazelcast.internal.nearcache.NearCacheManager
Lists all existing NearCache instances.
ListClearCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes all of the elements from this list (optional operation).
ListClearCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListClearCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListClearMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_CLEAR
ListClearMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListClearMessageTask
 
ListCompareAndRemoveAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes from this list all of its elements that are contained in the specified collection (optional operation).
ListCompareAndRemoveAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListCompareAndRemoveAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListCompareAndRemoveAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_COMPAREANDREMOVEALL
ListCompareAndRemoveAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRemoveAllMessageTask
 
ListCompareAndRetainAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Retains only the elements in this list that are contained in the specified collection (optional operation).
ListCompareAndRetainAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListCompareAndRetainAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListCompareAndRetainAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_COMPAREANDRETAINALL
ListCompareAndRetainAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRetainAllMessageTask
 
ListConfig - Class in com.hazelcast.config
Contains the configuration for an IList.
ListConfig() - Constructor for class com.hazelcast.config.ListConfig
 
ListConfig(String) - Constructor for class com.hazelcast.config.ListConfig
 
ListConfig(ListConfig) - Constructor for class com.hazelcast.config.ListConfig
 
ListConfigReadOnly - Class in com.hazelcast.internal.config
Contains the configuration for an IList (read-only).
ListConfigReadOnly(ListConfig) - Constructor for class com.hazelcast.internal.config.ListConfigReadOnly
 
ListContainer - Class in com.hazelcast.collection.impl.list
 
ListContainer() - Constructor for class com.hazelcast.collection.impl.list.ListContainer
 
ListContainer(String, NodeEngine) - Constructor for class com.hazelcast.collection.impl.list.ListContainer
 
ListContainsAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns true if this list contains all of the elements of the specified collection.
ListContainsAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListContainsAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListContainsAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_CONTAINSALL
ListContainsAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListContainsAllMessageTask
 
ListContainsCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns true if this list contains the specified element.
ListContainsCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListContainsCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListContainsMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_CONTAINS
ListContainsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListContainsMessageTask
 
listener - Variable in class com.hazelcast.topic.impl.reliable.MessageRunner
 
LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
LISTENER_INSTANCE - Static variable in class com.hazelcast.security.permission.ActionConstants
 
LISTENER_MEMBER - Static variable in class com.hazelcast.security.permission.ActionConstants
 
LISTENER_MIGRATION - Static variable in class com.hazelcast.security.permission.ActionConstants
 
LISTENER_REGISTRATION - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
LISTENER_WITH_PREDICATE_PRODUCES_NATURAL_EVENT_TYPES - Static variable in class com.hazelcast.map.impl.event.MapEventPublisherImpl
 
ListenerAdapter<T> - Interface in com.hazelcast.map.impl
Adapter for all IMap listeners.
ListenerAdapters - Class in com.hazelcast.map.impl
Contains support methods for creating various ListenerAdapter
listenerConfig - Variable in class com.hazelcast.client.impl.protocol.codec.CacheListenerRegistrationCodec.RequestParameters
The listener configuration.
ListenerConfig - Class in com.hazelcast.config
Contains the configuration for an EventListener.
ListenerConfig() - Constructor for class com.hazelcast.config.ListenerConfig
Creates a ListenerConfig without className/implementation.
ListenerConfig(String) - Constructor for class com.hazelcast.config.ListenerConfig
Creates a ListenerConfig with the given className.
ListenerConfig(ListenerConfig) - Constructor for class com.hazelcast.config.ListenerConfig
 
ListenerConfig(EventListener) - Constructor for class com.hazelcast.config.ListenerConfig
Creates a ListenerConfig with the given implementation.
ListenerConfigHolder - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
ListenerConfigHolder(int, String) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.ListenerConfigHolder
 
ListenerConfigHolder(int, Data) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.ListenerConfigHolder
 
ListenerConfigHolder(int, Data, String, boolean, boolean) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.ListenerConfigHolder
 
ListenerConfigHolderCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
ListenerConfigReadOnly - Class in com.hazelcast.internal.config
Contains the configuration for a Listener.
ListenerConfigReadOnly(ListenerConfig) - Constructor for class com.hazelcast.internal.config.ListenerConfigReadOnly
 
listenerConfigs - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddListConfigCodec.RequestParameters
item listener configurations
listenerConfigs - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
entry listener configurations
listenerConfigs - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMultiMapConfigCodec.RequestParameters
entry listener configurations
listenerConfigs - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddQueueConfigCodec.RequestParameters
item listeners configuration
listenerConfigs - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReliableTopicConfigCodec.RequestParameters
message listener configurations
listenerConfigs - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReplicatedMapConfigCodec.RequestParameters
entry listener configurations
listenerConfigs - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddSetConfigCodec.RequestParameters
item listener configurations
listenerConfigs - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddTopicConfigCodec.RequestParameters
message listener configurations
listenerConfigurations - Variable in class com.hazelcast.config.AbstractCacheConfig
The CacheEntryListenerConfigurations for the Configuration.
listenerFlags - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerCodec.RequestParameters
flags of enabled listeners.
listenerFlags - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyCodec.RequestParameters
flags of enabled listeners.
listenerFlags - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyWithPredicateCodec.RequestParameters
flags of enabled listeners.
listenerFlags - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerWithPredicateCodec.RequestParameters
flags of enabled listeners.
listenerFlags - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheEntryListenerCodec.RequestParameters
flags of enabled listeners.
listenerFlags - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheInvalidationListenerCodec.RequestParameters
flags of enabled listeners.
ListenerInfo - Class in com.hazelcast.client.impl.querycache.subscriber
Contains all listener specific information for ClientQueryCacheEventService.
ListenerInfo(EventFilter, ListenerAdapter, UUID) - Constructor for class com.hazelcast.client.impl.querycache.subscriber.ListenerInfo
 
ListenerMessageCodec - Interface in com.hazelcast.client.impl.spi.impl
 
ListenerMessageTask - Interface in com.hazelcast.client.impl.protocol.task
Marker interface for listener registration tasks
listenerName - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryAddListenerCodec.RequestParameters
Name of the MapListener which will be used to listen this QueryCache
ListenerWrapperEventFilter - Interface in com.hazelcast.internal.services
Contract point for EventFilter instances these wrap listeners.
listenMembershipEvents(Connection) - Method in class com.hazelcast.client.impl.spi.impl.ClientClusterServiceImpl
 
listenPartitionTable(Connection) - Method in class com.hazelcast.client.impl.spi.impl.ClientPartitionServiceImpl
 
ListGetAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Return the all elements of this collection
ListGetAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListGetAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListGetAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_GETALL
ListGetAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListGetAllMessageTask
 
ListGetCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the element at the specified position in this list
ListGetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListGetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_GET
ListGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListGetMessageTask
 
ListGetOperation - Class in com.hazelcast.collection.impl.list.operations
 
ListGetOperation() - Constructor for class com.hazelcast.collection.impl.list.operations.ListGetOperation
 
ListGetOperation(String, int) - Constructor for class com.hazelcast.collection.impl.list.operations.ListGetOperation
 
ListIndexOfCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the index of the first occurrence of the specified element in this list, or -1 if this list does not contain the element.
ListIndexOfCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListIndexOfCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListIndexOfMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_INDEXOF
ListIndexOfMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListIndexOfMessageTask
 
ListIndexOfOperation - Class in com.hazelcast.collection.impl.list.operations
 
ListIndexOfOperation() - Constructor for class com.hazelcast.collection.impl.list.operations.ListIndexOfOperation
 
ListIndexOfOperation(String, boolean, Data) - Constructor for class com.hazelcast.collection.impl.list.operations.ListIndexOfOperation
 
ListIntegerCodec - Class in com.hazelcast.client.impl.protocol.codec.builtin
 
ListIsEmptyCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns true if this list contains no elements
ListIsEmptyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListIsEmptyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListIsEmptyMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_ADDLISTENER
ListIsEmptyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListIsEmptyMessageTask
 
listIterator() - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
listIterator(int) - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
listIterator() - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
 
listIterator(int) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
 
listIterator() - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
 
listIterator(int) - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
 
ListIteratorCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns an iterator over the elements in this list in proper sequence.
ListIteratorCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListIteratorCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListIteratorMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_ITERATOR
ListIteratorMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListIteratorMessageTask
 
ListLastIndexOfCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the index of the last occurrence of the specified element in this list, or -1 if this list does not contain the element.
ListLastIndexOfCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListLastIndexOfCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListLastIndexOfMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_LASTINDEXOF
ListLastIndexOfMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListLastIndexOfMessageTask
 
ListListIteratorCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns a list iterator over the elements in this list (in proper sequence), starting at the specified position in the list.
ListListIteratorCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListListIteratorCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListListIteratorMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_LISTITERATOR
ListListIteratorMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListListIteratorMessageTask
 
ListLongCodec - Class in com.hazelcast.client.impl.protocol.codec.builtin
 
ListMBean - Class in com.hazelcast.internal.jmx
Management bean for IList
ListMBean(IList<?>, ManagementService) - Constructor for class com.hazelcast.internal.jmx.ListMBean
 
ListMultiFrameCodec - Class in com.hazelcast.client.impl.protocol.codec.builtin
 
ListPermission - Class in com.hazelcast.security.permission
 
ListPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ListPermission
 
ListProxyImpl<E> - Class in com.hazelcast.collection.impl.list
 
ListProxyImpl(String, NodeEngine, ListService) - Constructor for class com.hazelcast.collection.impl.list.ListProxyImpl
 
ListRemoveCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the first occurrence of the specified element from this list, if it is present (optional operation).
ListRemoveCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListRemoveCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListRemoveListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the specified item listener.
ListRemoveListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListRemoveListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListRemoveListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_REMOVELISTENER
ListRemoveListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListRemoveListenerMessageTask
 
ListRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_REMOVE
ListRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListRemoveMessageTask
 
ListRemoveOperation - Class in com.hazelcast.collection.impl.list.operations
 
ListRemoveOperation() - Constructor for class com.hazelcast.collection.impl.list.operations.ListRemoveOperation
 
ListRemoveOperation(String, int) - Constructor for class com.hazelcast.collection.impl.list.operations.ListRemoveOperation
 
ListRemoveWithIndexCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the element at the specified position in this list (optional operation).
ListRemoveWithIndexCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListRemoveWithIndexCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListRemoveWithIndexMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_REMOVEWITHINDEX
ListRemoveWithIndexMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListRemoveWithIndexMessageTask
 
ListReplicationOperation - Class in com.hazelcast.collection.impl.list.operations
 
ListReplicationOperation() - Constructor for class com.hazelcast.collection.impl.list.operations.ListReplicationOperation
 
ListReplicationOperation(Map<String, CollectionContainer>, int, int) - Constructor for class com.hazelcast.collection.impl.list.operations.ListReplicationOperation
 
ListScheduledTaskHandlerCodec - Class in com.hazelcast.client.impl.protocol.codec.builtin
 
ListService - Class in com.hazelcast.collection.impl.list
 
ListService(NodeEngine) - Constructor for class com.hazelcast.collection.impl.list.ListService
 
ListSetBackupOperation - Class in com.hazelcast.collection.impl.list.operations
 
ListSetBackupOperation() - Constructor for class com.hazelcast.collection.impl.list.operations.ListSetBackupOperation
 
ListSetBackupOperation(String, long, long, Data) - Constructor for class com.hazelcast.collection.impl.list.operations.ListSetBackupOperation
 
ListSetCodec - Class in com.hazelcast.client.impl.protocol.codec
The element previously at the specified position
ListSetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListSetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_SET
ListSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListSetMessageTask
 
ListSetOperation - Class in com.hazelcast.collection.impl.list.operations
 
ListSetOperation() - Constructor for class com.hazelcast.collection.impl.list.operations.ListSetOperation
 
ListSetOperation(String, int, Data) - Constructor for class com.hazelcast.collection.impl.list.operations.ListSetOperation
 
ListSizeCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the number of elements in this list.
ListSizeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListSizeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_SIZE
ListSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListSizeMessageTask
 
ListSubCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns a view of the portion of this list between the specified from, inclusive, and to, exclusive.(If from and to are equal, the returned list is empty.) The returned list is backed by this list, so non-structural changes in the returned list are reflected in this list, and vice-versa.
ListSubCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListSubCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ListSubMessageTask - Class in com.hazelcast.client.impl.protocol.task.list
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ListMessageType#LIST_SUB
ListSubMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.list.ListSubMessageTask
 
ListSubOperation - Class in com.hazelcast.collection.impl.list.operations
 
ListSubOperation() - Constructor for class com.hazelcast.collection.impl.list.operations.ListSubOperation
 
ListSubOperation(String, int, int) - Constructor for class com.hazelcast.collection.impl.list.operations.ListSubOperation
 
ListUUIDCodec - Class in com.hazelcast.client.impl.protocol.codec.builtin
 
LITE_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
A MemberSelector instance that selects only lite members that own no partition
liteMember - Variable in class com.hazelcast.cluster.impl.AbstractMember
 
liteMember(boolean) - Method in class com.hazelcast.cluster.impl.MemberImpl.Builder
 
liteMember - Variable in class com.hazelcast.internal.cluster.impl.JoinMessage
 
LiveOperationRegistry - Class in com.hazelcast.internal.metrics.impl
 
LiveOperationRegistry() - Constructor for class com.hazelcast.internal.metrics.impl.LiveOperationRegistry
 
LiveOperations - Interface in com.hazelcast.spi.impl.operationservice
InvocationMonitor passes instances of this type to each LiveOperationsTracker so it can contribute the call IDs of invocations it is responsible for.
LiveOperationsTracker - Interface in com.hazelcast.spi.impl.operationservice
Can be implemented by a Service to track live operations.
liveQueueCount() - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Returns the number of remaining live queues, i.e., ConcurrentConveyor.queueCount() minus the number of queues nulled out by calling ConcurrentConveyor.removeQueue(int).
load(K) - Method in class com.hazelcast.cache.impl.LatencyTrackingCacheLoader
 
load(Long) - Method in class com.hazelcast.collection.impl.queue.LatencyTrackingQueueStore
 
load(Long) - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
 
load(Long) - Method in interface com.hazelcast.collection.QueueStore
Loads the value of a given key.
load(String) - Static method in class com.hazelcast.config.ConfigLoader
 
load() - Method in interface com.hazelcast.cp.internal.raft.impl.persistence.RaftStateLoader
Restores the persisted Raft state from the storage layer and returns a fully initialized RestoredRaftState object.
load() - Method in interface com.hazelcast.internal.networking.nio.MigratablePipeline
Get 'load' recorded by the current pipeline.
load() - Method in class com.hazelcast.internal.networking.nio.NioInboundPipeline
 
load() - Method in class com.hazelcast.internal.networking.nio.NioOutboundPipeline
 
load(Class<T>, String, ClassLoader) - Static method in class com.hazelcast.internal.util.ServiceLoader
 
load(InputStream, String) - Static method in class com.hazelcast.internal.yaml.YamlLoader
Loads a YAML document from an InputStream and builds a YamlNode tree that is under the provided top-level rootName key.
load(InputStream) - Static method in class com.hazelcast.internal.yaml.YamlLoader
Loads a YAML document from an InputStream and builds a YamlNode tree.
load(Reader, String) - Static method in class com.hazelcast.internal.yaml.YamlLoader
Loads a YAML document from an Reader and builds a YamlNode tree that is under the provided top-level rootName key.
load(Reader) - Static method in class com.hazelcast.internal.yaml.YamlLoader
Loads a YAML document from an Reader and builds a YamlNode tree.
load(String, String) - Static method in class com.hazelcast.internal.yaml.YamlLoader
Loads a YAML document from an String and builds a YamlNode tree that is under the provided top-level rootName key.
load(String) - Static method in class com.hazelcast.internal.yaml.YamlLoader
Loads a YAML document from an String and builds a YamlNode tree.
load(K) - Method in class com.hazelcast.map.impl.LatencyTrackingMapLoader
 
load(K) - Method in class com.hazelcast.map.impl.LatencyTrackingMapStore
 
load(K) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
 
load(Data) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
load(Data) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
load(Object) - Method in class com.hazelcast.map.impl.MapStoreWrapper
 
load(K) - Method in interface com.hazelcast.map.MapLoader
Loads the value of a given key.
load(K) - Method in class com.hazelcast.map.MapStoreAdapter
Loads the value of a given key.
load(long) - Method in class com.hazelcast.ringbuffer.impl.RingbufferStoreWrapper
 
load(long) - Method in interface com.hazelcast.ringbuffer.RingbufferStore
Loads the value of a given sequence.
load(Map) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledRunnableAdapter
 
load(Map<K, V>) - Method in interface com.hazelcast.scheduledexecutor.StatefulTask
Task callback to initialize its inner state, after a replica promotion, from the given map.
LOAD_ALL - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
LOAD_ALL - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
LOAD_ALL_FACTORY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
LOAD_ALL_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
LOAD_BALANCING_BYTE - Static variable in class com.hazelcast.internal.networking.nio.NioPipeline
 
LOAD_BALANCING_FRAME - Static variable in class com.hazelcast.internal.networking.nio.NioPipeline
 
LOAD_BALANCING_HANDLE - Static variable in class com.hazelcast.internal.networking.nio.NioPipeline
 
LOAD_MAP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
loadable(K) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
Used in IMap.loadAll(boolean) calls.
loadable(Data) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
loadable(Data) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
loadAddresses() - Method in interface com.hazelcast.client.impl.connection.AddressProvider
 
loadAddresses() - Method in class com.hazelcast.client.impl.spi.impl.DefaultAddressProvider
 
loadAddresses() - Method in class com.hazelcast.client.impl.spi.impl.discovery.RemoteAddressProvider
 
loadAll(Set<Data>, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
loadAll(Set<? extends K>, boolean, CompletionListener) - Method in class com.hazelcast.cache.impl.CacheProxy
 
loadAll(Set<Data>, boolean) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Synchronously loads the specified entries into the cache using the configured CacheLoader for the given keys.
loadAll(Iterable<? extends K>) - Method in class com.hazelcast.cache.impl.LatencyTrackingCacheLoader
 
loadAll(Set<? extends K>, boolean, CompletionListener) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
loadAll(boolean) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
loadAll(Set<K>, boolean) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
loadAll(boolean) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
loadAll(Collection<Long>) - Method in class com.hazelcast.collection.impl.queue.LatencyTrackingQueueStore
 
loadAll(Collection<Long>) - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
 
loadAll(Collection<Long>) - Method in interface com.hazelcast.collection.QueueStore
Loads the given keys.
loadAll(boolean) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
loadAll(Set<K>, boolean) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
loadAll(Set<? extends K>, boolean, CompletionListener) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
loadAll(boolean) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
loadAll(Set<K>, boolean) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
loadAll(Set<? extends K>, boolean, CompletionListener) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
loadAll(boolean) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
loadAll(Set<K>, boolean) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
loadAll(Set<? extends K>, boolean, CompletionListener) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
loadAll(boolean) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
loadAll(Set<K>, boolean) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
loadAll(Set<? extends K>, boolean, CompletionListener) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
loadAll(boolean) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
loadAll(Set<K>, boolean) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
loadAll(Set<? extends K>, boolean, CompletionListener) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
loadAll(boolean) - Method in interface com.hazelcast.map.IMap
Loads all keys into the store.
loadAll(Set<K>, boolean) - Method in interface com.hazelcast.map.IMap
Loads the given keys.
loadAll(Collection<K>) - Method in class com.hazelcast.map.impl.LatencyTrackingMapLoader
 
loadAll(Collection<K>) - Method in class com.hazelcast.map.impl.LatencyTrackingMapStore
 
loadAll(Collection) - Method in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
 
loadAll(Collection) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
Loads values for the provided keys if a MapLoader is configured for this map.
loadAll(Collection) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
Loads values for the provided keys if a MapLoader is configured for this map.
loadAll(Collection) - Method in class com.hazelcast.map.impl.MapStoreWrapper
 
loadAll(boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
loadAll(Set<K>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
loadAll(boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
loadAll(boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Triggers key and value loading if there is no ongoing or completed key loading task, otherwise does nothing.
loadAll(Collection<K>) - Method in interface com.hazelcast.map.MapLoader
Loads given keys.
loadAll(Collection<K>) - Method in class com.hazelcast.map.MapStoreAdapter
Loads given keys.
loadAllCacheEntry(Set<Data>) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
loadAllFromStore(List<Data>, boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
loadAllFromStore(List<Data>, boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Triggers loading values for the given keys from the defined MapLoader.
loadAllInternal(Set<? extends K>, List<Data>, boolean, CompletionListener) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
loadAllInternal(boolean, Collection<?>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
loadAllInternal(boolean, Collection<?>) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
loadAllInternal(boolean) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
loadAllKeys() - Method in class com.hazelcast.collection.impl.queue.LatencyTrackingQueueStore
 
loadAllKeys() - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
 
loadAllKeys() - Method in interface com.hazelcast.collection.QueueStore
Loads all of the keys from the store.
loadAllKeys() - Method in class com.hazelcast.map.impl.LatencyTrackingMapLoader
 
loadAllKeys() - Method in class com.hazelcast.map.impl.LatencyTrackingMapStore
 
loadAllKeys() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
Returns an Iterable over all keys or an empty iterable if there is no map loader configured for this map.
loadAllKeys() - Method in class com.hazelcast.map.impl.MapStoreWrapper
Returns an Iterable of all keys or null if a map loader is not configured for this map.
loadAllKeys() - Method in interface com.hazelcast.map.MapLoader
Loads all of the keys from the store.
loadAllKeys() - Method in class com.hazelcast.map.MapStoreAdapter
Loads all of the keys from the store.
LoadAllOperation - Class in com.hazelcast.map.impl.operation
Triggers loading values for the given keys from the defined MapLoader.
LoadAllOperation() - Constructor for class com.hazelcast.map.impl.operation.LoadAllOperation
 
LoadAllOperation(String, List<Data>, boolean) - Constructor for class com.hazelcast.map.impl.operation.LoadAllOperation
 
loadAwareIterator(long, boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
loadAwareIterator(long, boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Iterates over record store entries but first waits map store to load.
LoadBalancer - Interface in com.hazelcast.client
LoadBalancer allows you to send operations to one of a number of endpoints(Members).
loadClass(ClassLoader, String) - Static method in class com.hazelcast.internal.nio.ClassLoaderUtil
 
loadClass(String, boolean) - Method in class com.hazelcast.internal.usercodedeployment.impl.ClassSource
 
loadClass(String, boolean) - Method in class com.hazelcast.internal.usercodedeployment.UserCodeDeploymentClassLoader
 
loadConfigurationFromClasspath(String) - Method in class com.hazelcast.config.AbstractConfigLocator
 
loadDefaultConfigurationFromClasspath(String) - Method in class com.hazelcast.config.AbstractConfigLocator
 
loaded - Variable in class com.hazelcast.map.impl.operation.MapReplicationStateHolder
 
loadEntries(Set<Data>, Address) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
loadFactor() - Method in class com.hazelcast.internal.util.collection.BiInt2ObjectMap
Get the load factor beyond which the map will increase size.
loadFactor() - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
Get the load factor beyond which the map will increase size.
loadFactor() - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
Get the load factor beyond which the map will increase size.
loadFactor() - Method in class com.hazelcast.internal.util.collection.OAHashSet
Returns the load factor of the set
loadFromSystemProperty(String, Collection<String>) - Method in class com.hazelcast.config.AbstractConfigLocator
 
loadFromSystemPropertyOrFailOnUnacceptedSuffix(String, Collection<String>) - Method in class com.hazelcast.config.AbstractConfigLocator
 
loadFromWorkingDirectory(String) - Method in class com.hazelcast.config.AbstractConfigLocator
 
loadingFutures - Variable in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
A collection of futures representing pending completion of the key and value loading tasks.
loadInternal(Set<K>, Iterable<Data>, boolean) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
loadKeys(DataStructureAdapter<Object, ?>) - Method in class com.hazelcast.internal.nearcache.impl.preloader.NearCachePreloader
Loads the values via a stored key file into the supplied DataStructureAdapter.
loadKeys(DataStructureAdapter<Object, ?>) - Method in class com.hazelcast.internal.nearcache.impl.store.BaseHeapNearCacheRecordStore
 
loadKeys(DataStructureAdapter<Object, ?>) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
Loads the keys into the Near Cache.
LoadMapOperation - Class in com.hazelcast.map.impl.operation
Triggers map loading from a map store.
LoadMapOperation() - Constructor for class com.hazelcast.map.impl.operation.LoadMapOperation
 
LoadMapOperation(String, boolean) - Constructor for class com.hazelcast.map.impl.operation.LoadMapOperation
 
loadPivot(long) - Method in class com.hazelcast.internal.util.sort.IntMemArrayQuickSorter
 
loadPivot(long) - Method in class com.hazelcast.internal.util.sort.LongMemArrayQuickSorter
 
loadPivot(long) - Method in class com.hazelcast.internal.util.sort.QuickSorter
Loads the data from the given index as needed to satisfy later calls to QuickSorter.isLessThanPivot(long) and QuickSorter.isGreaterThanPivot(long).
loadRecordOrNull(Data, boolean, Address) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
loadRecordOrNull(Data, boolean, Address) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
loadSchemaFile(String) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
loadType - Variable in class com.hazelcast.internal.networking.nio.NioPipeline
 
LOCAL_GET_OP - Static variable in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongDataSerializerHook
 
LOCAL_MEMBER_RESET - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
LOCAL_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
A MemberSelector instance that selects only local members
LOCAL_NODE - Static variable in class com.hazelcast.map.impl.query.Target
 
LocalCacheStats - Interface in com.hazelcast.monitor
Local cache statistics to be used by MemberState implementations.
LocalCacheStatsImpl - Class in com.hazelcast.monitor.impl
Default implementation of LocalCacheStats
LocalCacheStatsImpl() - Constructor for class com.hazelcast.monitor.impl.LocalCacheStatsImpl
 
LocalCacheStatsImpl(CacheStatistics) - Constructor for class com.hazelcast.monitor.impl.LocalCacheStatsImpl
 
LocalCacheWideEventData - Class in com.hazelcast.map.impl.querycache.event
EventData which is used only for the subscriber end of a query cache and only for query cache wide events like clearing all items together.
LocalCacheWideEventData(String, int, int) - Constructor for class com.hazelcast.map.impl.querycache.event.LocalCacheWideEventData
 
LOCALE_INTERNAL - Static variable in class com.hazelcast.internal.util.StringUtil
LOCALE_INTERNAL is the default locale for string operations and number formatting.
localEndpoint() - Method in class com.hazelcast.cp.internal.raft.impl.persistence.RestoredRaftState
 
localEndpoint() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
 
LocalEntryEventData<K,V> - Class in com.hazelcast.map.impl.querycache.event
EventData which is used only for the subscriber end of a query cache and only for entry based events.
LocalEntryEventData(SerializationService, String, int, Object, Object, Object, int) - Constructor for class com.hazelcast.map.impl.querycache.event.LocalEntryEventData
 
LocalEventDispatcher - Class in com.hazelcast.spi.impl.eventservice.impl
A StripedRunnable responsible of processing the LocalEventDispatcher.event on a thread defined by the LocalEventDispatcher.orderKey.
LocalEventDispatcher(EventServiceImpl, String, Object, Object, int, long) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.LocalEventDispatcher
 
LocalExecutorStats - Interface in com.hazelcast.monitor
Local executor service statistics to be used by MemberState implementations.
LocalExecutorStatsImpl - Class in com.hazelcast.monitor.impl
 
LocalExecutorStatsImpl() - Constructor for class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
 
LocalFlakeIdGeneratorStats - Interface in com.hazelcast.monitor
local flake ID statistics to be used by MemberState implementations.
LocalFlakeIdGeneratorStatsImpl - Class in com.hazelcast.monitor.impl
 
LocalFlakeIdGeneratorStatsImpl() - Constructor for class com.hazelcast.monitor.impl.LocalFlakeIdGeneratorStatsImpl
 
LocalGCStats - Interface in com.hazelcast.monitor
Local GC statistics to be used by MemberState implementations.
LocalGCStatsImpl - Class in com.hazelcast.monitor.impl
 
LocalGCStatsImpl() - Constructor for class com.hazelcast.monitor.impl.LocalGCStatsImpl
 
LocalGCStatsImpl(GarbageCollectorStats) - Constructor for class com.hazelcast.monitor.impl.LocalGCStatsImpl
 
localGet(QueryPolicy) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
localGetAsync(QueryPolicy) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
LocalGetOp - Class in com.hazelcast.cp.internal.datastructures.atomiclong.operation
LocalGetOp() - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.operation.LocalGetOp
 
LocalGetOp(String) - Constructor for class com.hazelcast.cp.internal.datastructures.atomiclong.operation.LocalGetOp
 
localHeapCost() - Method in class com.hazelcast.internal.jmx.MapMBean
 
LocalIndexStats - Interface in com.hazelcast.monitor
Provides local statistics for an index to be used by MemberState implementations.
LocalIndexStatsImpl - Class in com.hazelcast.monitor.impl
Implementation of local index stats that backs the stats exposed through the public API.
LocalIndexStatsImpl() - Constructor for class com.hazelcast.monitor.impl.LocalIndexStatsImpl
 
LocalInstanceStats - Interface in com.hazelcast.monitor
Base interface for local instance statistics.
localKeySet() - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
localKeySet(Predicate) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
localKeySet() - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
localKeySet() - Method in interface com.hazelcast.map.IMap
Returns the locally owned immutable set of keys.
localKeySet(Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
Returns an immutable set of the keys of matching locally owned entries.
localKeySet() - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
localKeySet(Predicate) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
localKeySet(String) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
localKeySet() - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
localKeySet() - Method in interface com.hazelcast.multimap.MultiMap
Returns the locally owned set of keys.
localKeySetInternal() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
localLock(Data, UUID, long, long, long) - Method in interface com.hazelcast.internal.locksupport.LockStore
Lock a specific key on a local partition only.
localLock(Data, UUID, long, long, long) - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
localLock(Data, UUID, long, long, long) - Method in class com.hazelcast.internal.locksupport.LockStoreProxy
 
localLock(Data, UUID, long, long, long) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
localLock(Data, UUID, long, long, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
LocalLockCleanupOperation - Class in com.hazelcast.internal.locksupport.operations
Locally executed operation which unlocks a lock if it is held by a specific owner.
LocalLockCleanupOperation() - Constructor for class com.hazelcast.internal.locksupport.operations.LocalLockCleanupOperation
This constructor should not be used to obtain an instance of this class; it exists to fulfill IdentifiedDataSerializable coding conventions.
LocalLockCleanupOperation(ObjectNamespace, Data, UUID) - Constructor for class com.hazelcast.internal.locksupport.operations.LocalLockCleanupOperation
 
LocalMapOnDemandCalculatedStats() - Constructor for class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
 
LocalMapStats - Interface in com.hazelcast.monitor
Local map statistics to be used by MemberState implementations.
LocalMapStatsImpl - Class in com.hazelcast.monitor.impl
Default implementation of LocalMapStats
LocalMapStatsImpl() - Constructor for class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
LocalMapStatsProvider - Class in com.hazelcast.map.impl
Provides node local statistics of a map via LocalMapStatsProvider.createLocalMapStats(java.lang.String) and also holds all LocalMapStatsImpl implementations of all maps.
LocalMapStatsProvider(MapServiceContext) - Constructor for class com.hazelcast.map.impl.LocalMapStatsProvider
 
localMapStatsProvider - Variable in class com.hazelcast.map.impl.query.QueryRunner
 
LocalMapStatsProvider.LocalMapOnDemandCalculatedStats - Class in com.hazelcast.map.impl
 
LocalMapStatsSupplier - Class in com.hazelcast.internal.jmx.suppliers
Implementation of StatsSupplier for LocalMapStats
LocalMapStatsSupplier(IMap) - Constructor for class com.hazelcast.internal.jmx.suppliers.LocalMapStatsSupplier
 
LocalMapStatsUtil - Class in com.hazelcast.map.impl
Utility methods for LocalMapStatsImpl
localMember() - Method in class com.hazelcast.client.impl.MemberImpl
 
localMember(boolean) - Method in class com.hazelcast.cluster.impl.MemberImpl.Builder
 
localMember() - Method in class com.hazelcast.cluster.impl.MemberImpl
 
localMember() - Method in interface com.hazelcast.cluster.Member
Returns true if this member is the local member.
localMember() - Method in class com.hazelcast.cp.internal.raft.impl.task.RaftNodeStatusAwareTask
 
LocalMemberResetException - Exception in com.hazelcast.core
An exception provided to MemberLeftException as a cause when the local member is resetting itself
LocalMemberResetException(String) - Constructor for exception com.hazelcast.core.LocalMemberResetException
 
LocalMemoryStats - Interface in com.hazelcast.monitor
Local memory statistics to be used by MemberState implementations.
LocalMemoryStatsImpl - Class in com.hazelcast.monitor.impl
 
LocalMemoryStatsImpl() - Constructor for class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
LocalMemoryStatsImpl(MemoryStats) - Constructor for class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
LocalMultiMapStats - Interface in com.hazelcast.monitor
Local multi map statistics to be used by MemberState implementations.
LocalMultiMapStatsImpl - Class in com.hazelcast.monitor.impl
 
LocalMultiMapStatsImpl() - Constructor for class com.hazelcast.monitor.impl.LocalMultiMapStatsImpl
 
LocalMultiMapStatsSupplier - Class in com.hazelcast.internal.jmx.suppliers
Implementation of StatsSupplier for LocalMultiMapStats
LocalMultiMapStatsSupplier(MultiMap) - Constructor for class com.hazelcast.internal.jmx.suppliers.LocalMultiMapStatsSupplier
 
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.CacheAddEntryListenerCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.CacheAddInvalidationListenerCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.CacheAddNearCacheInvalidationListenerCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.CacheAddPartitionLostListenerCodec.RequestParameters
if true only node that has the partition sends the request, if false sends all partition lost events.
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAddDistributedObjectListenerCodec.RequestParameters
If set to true, the server adds the listener only to itself, otherwise the listener is is added for all members in the cluster.
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAddMembershipListenerCodec.RequestParameters
if true only master node sends events, otherwise all registered nodes send all membership changes.
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionLostListenerCodec.RequestParameters
if true only node that has the partition sends the request, if false sends all partition lost events.
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryAddListenerCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.ListAddListenerCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyWithPredicateCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerWithPredicateCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheEntryListenerCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheInvalidationListenerCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddPartitionLostListenerCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerToKeyCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.QueueAddListenerCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyWithPredicateCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerWithPredicateCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddNearCacheEntryListenerCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.SetAddListenerCodec.RequestParameters
if true fires events that originated from this node only, otherwise fires all events
localOnly - Variable in class com.hazelcast.client.impl.protocol.codec.TopicAddMessageListenerCodec.RequestParameters
if true listens only local events on registered member
LocalOperationStats - Interface in com.hazelcast.monitor
Local operation statistics to be used by MemberState implementations.
LocalOperationStatsImpl - Class in com.hazelcast.monitor.impl
Hazelcast statistic implementations for local operations.
LocalOperationStatsImpl() - Constructor for class com.hazelcast.monitor.impl.LocalOperationStatsImpl
 
LocalOperationStatsImpl(Node) - Constructor for class com.hazelcast.monitor.impl.LocalOperationStatsImpl
 
LocalPNCounterStats - Interface in com.hazelcast.monitor
Local statistics of a single PN counter to be used by MemberState implementations.
LocalPNCounterStatsImpl - Class in com.hazelcast.monitor.impl
Local PN counter statistics thread safe implementation
LocalPNCounterStatsImpl() - Constructor for class com.hazelcast.monitor.impl.LocalPNCounterStatsImpl
 
LocalQueueStats - Interface in com.hazelcast.monitor
Local queue statistics to be used by MemberState implementations.
LocalQueueStatsImpl - Class in com.hazelcast.monitor.impl
 
LocalQueueStatsImpl() - Constructor for class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
LocalQueueStatsSupplier - Class in com.hazelcast.internal.jmx.suppliers
Implementation of StatsSupplier for LocalQueueStats
LocalQueueStatsSupplier(IQueue) - Constructor for class com.hazelcast.internal.jmx.suppliers.LocalQueueStatsSupplier
 
LocalRecordStoreStats - Interface in com.hazelcast.monitor
Local record store statistics to be used by MemberState implementations.
LocalRecordStoreStatsImpl - Class in com.hazelcast.monitor.impl
 
LocalRecordStoreStatsImpl() - Constructor for class com.hazelcast.monitor.impl.LocalRecordStoreStatsImpl
 
LocalReplicatedMapStats - Interface in com.hazelcast.monitor
Local replicated map statistics to be used by MemberState implementations.
LocalReplicatedMapStatsImpl - Class in com.hazelcast.monitor.impl
This class collects statistics about the replication map usage for management center and is able to transform those between wire format and instance view.
LocalReplicatedMapStatsImpl() - Constructor for class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
LocalReplicatedMapStatsSupplier - Class in com.hazelcast.internal.jmx.suppliers
LocalReplicatedMapStatsSupplier(ReplicatedMap<?, ?>) - Constructor for class com.hazelcast.internal.jmx.suppliers.LocalReplicatedMapStatsSupplier
 
LocalRetryableExecution - Class in com.hazelcast.internal.util
Class encapsulating local execution with retry logic.
localSocketAddress() - Method in class com.hazelcast.internal.networking.AbstractChannel
 
localSocketAddress() - Method in interface com.hazelcast.internal.networking.Channel
 
LocalStatsDelegate<T> - Class in com.hazelcast.internal.jmx
Provides LocalStats for MapMBean, MultiMapMBean, QueueMBean So that statistics are only created in given internal
LocalStatsDelegate(StatsSupplier<T>, long) - Constructor for class com.hazelcast.internal.jmx.LocalStatsDelegate
 
LocalTopicStats - Interface in com.hazelcast.monitor
Local topic statistics to be used by MemberState implementations.
LocalTopicStatsImpl - Class in com.hazelcast.monitor.impl
 
LocalTopicStatsImpl() - Constructor for class com.hazelcast.monitor.impl.LocalTopicStatsImpl
 
localTotal() - Method in class com.hazelcast.internal.jmx.MapMBean
 
localTotal() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
 
localTotal() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
LocalWanPublisherStats - Interface in com.hazelcast.monitor
Local WAN publisher statistics to be used by MemberState implementations.
LocalWanPublisherStatsImpl - Class in com.hazelcast.monitor.impl
 
LocalWanPublisherStatsImpl() - Constructor for class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
LocalWanStats - Interface in com.hazelcast.monitor
Local WAN statistics to be used by MemberState implementations.
LocalWanStatsImpl - Class in com.hazelcast.monitor.impl
Local WAN replication statistics for a single WAN replication scheme.
LocalWanStatsImpl() - Constructor for class com.hazelcast.monitor.impl.LocalWanStatsImpl
 
locateConfig(String) - Static method in class com.hazelcast.config.ConfigLoader
 
locateDefault() - Method in class com.hazelcast.client.config.XmlClientConfigLocator
 
locateDefault() - Method in class com.hazelcast.client.config.XmlClientFailoverConfigLocator
 
locateDefault() - Method in class com.hazelcast.client.config.YamlClientConfigLocator
 
locateDefault() - Method in class com.hazelcast.client.config.YamlClientFailoverConfigLocator
 
locateDefault() - Method in class com.hazelcast.config.AbstractConfigLocator
Locates the default configuration file.
locateDefault() - Method in class com.hazelcast.config.XmlConfigLocator
 
locateDefault() - Method in class com.hazelcast.config.YamlConfigLocator
 
locateEverywhere() - Method in class com.hazelcast.config.AbstractConfigLocator
 
locateFromSystemProperty() - Method in class com.hazelcast.client.config.XmlClientConfigLocator
 
locateFromSystemProperty() - Method in class com.hazelcast.client.config.XmlClientFailoverConfigLocator
 
locateFromSystemProperty() - Method in class com.hazelcast.client.config.YamlClientConfigLocator
 
locateFromSystemProperty() - Method in class com.hazelcast.client.config.YamlClientFailoverConfigLocator
 
locateFromSystemProperty() - Method in class com.hazelcast.config.AbstractConfigLocator
Locates the configuration file in a system property.
locateFromSystemProperty() - Method in class com.hazelcast.config.XmlConfigLocator
 
locateFromSystemProperty() - Method in class com.hazelcast.config.YamlConfigLocator
 
locateFromSystemPropertyOrFailOnUnacceptedSuffix() - Method in class com.hazelcast.client.config.XmlClientConfigLocator
 
locateFromSystemPropertyOrFailOnUnacceptedSuffix() - Method in class com.hazelcast.client.config.XmlClientFailoverConfigLocator
 
locateFromSystemPropertyOrFailOnUnacceptedSuffix() - Method in class com.hazelcast.client.config.YamlClientConfigLocator
 
locateFromSystemPropertyOrFailOnUnacceptedSuffix() - Method in class com.hazelcast.client.config.YamlClientFailoverConfigLocator
 
locateFromSystemPropertyOrFailOnUnacceptedSuffix() - Method in class com.hazelcast.config.AbstractConfigLocator
Locates the configuration file in a system property or throws HazelcastException if the suffix of the referenced file is not in the accepted list of the locator.
locateFromSystemPropertyOrFailOnUnacceptedSuffix() - Method in class com.hazelcast.config.XmlConfigLocator
 
locateFromSystemPropertyOrFailOnUnacceptedSuffix() - Method in class com.hazelcast.config.YamlConfigLocator
 
locateInWorkDir() - Method in class com.hazelcast.client.config.XmlClientConfigLocator
 
locateInWorkDir() - Method in class com.hazelcast.client.config.XmlClientFailoverConfigLocator
 
locateInWorkDir() - Method in class com.hazelcast.client.config.YamlClientConfigLocator
 
locateInWorkDir() - Method in class com.hazelcast.client.config.YamlClientFailoverConfigLocator
 
locateInWorkDir() - Method in class com.hazelcast.config.AbstractConfigLocator
Locates the configuration file in the working directory.
locateInWorkDir() - Method in class com.hazelcast.config.XmlConfigLocator
 
locateInWorkDir() - Method in class com.hazelcast.config.YamlConfigLocator
 
locateInWorkDirOrOnClasspath() - Method in class com.hazelcast.config.AbstractConfigLocator
 
locateOnClasspath() - Method in class com.hazelcast.client.config.XmlClientConfigLocator
 
locateOnClasspath() - Method in class com.hazelcast.client.config.XmlClientFailoverConfigLocator
 
locateOnClasspath() - Method in class com.hazelcast.client.config.YamlClientConfigLocator
 
locateOnClasspath() - Method in class com.hazelcast.client.config.YamlClientFailoverConfigLocator
 
locateOnClasspath() - Method in class com.hazelcast.config.AbstractConfigLocator
Locates the configuration file on the classpath.
locateOnClasspath() - Method in class com.hazelcast.config.XmlConfigLocator
 
locateOnClasspath() - Method in class com.hazelcast.config.YamlConfigLocator
 
Location - Class in com.hazelcast.internal.json
An immutable object that represents a location in the parsed text.
lock() - Method in class com.hazelcast.client.cp.internal.datastructures.lock.FencedLockProxy
 
lock(K) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
lock(K, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
lock(K) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
lock(K, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
Lock - Class in com.hazelcast.cp.internal.datastructures.lock
State-machine implementation of the Raft-based lock
lock() - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
lock() - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock.
lock(String, String) - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
lock(String, String) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
LOCK - Static variable in class com.hazelcast.internal.locksupport.LockDataSerializerHook
 
lock(NodeEngine, Data) - Method in class com.hazelcast.internal.locksupport.LockProxySupport
 
lock(NodeEngine, Data, long) - Method in class com.hazelcast.internal.locksupport.LockProxySupport
 
lock(Data, UUID, long, long, long) - Method in interface com.hazelcast.internal.locksupport.LockStore
Lock a specific key.
lock(Data, UUID, long, long, long) - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
lock(Data, UUID, long, long, long) - Method in class com.hazelcast.internal.locksupport.LockStoreProxy
 
lock(K) - Method in interface com.hazelcast.map.IMap
Acquires the lock for the specified key.
lock(K, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Acquires the lock for the specified key for the specified lease time.
lock(K) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
lock(Object, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
lock(Data, UUID, long, long, long) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
lock(Data, UUID, long, long, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
lock(K) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
lock(K, long, TimeUnit) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
lock(K) - Method in interface com.hazelcast.multimap.MultiMap
Acquires a lock for the specified key.
lock(K, long, TimeUnit) - Method in interface com.hazelcast.multimap.MultiMap
Acquires the lock for the specified key for the specified lease time.
LOCK_ACQUIRE_LIMIT_REACHED_EXCEPTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
LOCK_AWARE_LAZY_MAP_ENTRY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
LOCK_BACKUP - Static variable in class com.hazelcast.internal.locksupport.LockDataSerializerHook
 
LOCK_CLUSTER_STATE - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
LOCK_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
LOCK_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
LOCK_ENDPOINT - Static variable in class com.hazelcast.cp.internal.datastructures.lock.LockDataSerializerHook
 
LOCK_INVOCATION_KEY - Static variable in class com.hazelcast.cp.internal.datastructures.lock.LockDataSerializerHook
 
LOCK_MAX_LEASE_TIME_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
LOCK_OP - Static variable in class com.hazelcast.cp.internal.datastructures.lock.LockDataSerializerHook
 
LOCK_OWNERSHIP_LOST_EXCEPTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
LOCK_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
LOCK_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
LOCK_REPLICATION - Static variable in class com.hazelcast.internal.locksupport.LockDataSerializerHook
 
LOCK_RESOURCE - Static variable in class com.hazelcast.internal.locksupport.LockDataSerializerHook
 
LOCK_STORE - Static variable in class com.hazelcast.internal.locksupport.LockDataSerializerHook
 
LockAcquireLimitReachedException - Exception in com.hazelcast.cp.lock.exception
Thrown when the current lock holder could not acquired the lock reentrantly because the configured lock acquire limit is reached.
LockAcquireLimitReachedException() - Constructor for exception com.hazelcast.cp.lock.exception.LockAcquireLimitReachedException
 
LockAcquireLimitReachedException(String) - Constructor for exception com.hazelcast.cp.lock.exception.LockAcquireLimitReachedException
 
lockAndGetFence() - Method in class com.hazelcast.client.cp.internal.datastructures.lock.FencedLockProxy
 
lockAndGetFence() - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
lockAndGetFence() - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock and returns the fencing token assigned to the current thread for this lock acquire.
LockAware - Interface in com.hazelcast.map
Determines if the object implementing this interface is locked or not.
LockAwareLazyMapEntry - Class in com.hazelcast.map.impl
Specialization of the LazyMapEntry that is LockAware.
LockAwareLazyMapEntry() - Constructor for class com.hazelcast.map.impl.LockAwareLazyMapEntry
 
LockAwareLazyMapEntry(Data, Object, InternalSerializationService, Extractors, Boolean) - Constructor for class com.hazelcast.map.impl.LockAwareLazyMapEntry
 
LockAwareOperation - Class in com.hazelcast.map.impl.operation
 
LockAwareOperation() - Constructor for class com.hazelcast.map.impl.operation.LockAwareOperation
 
LockAwareOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.LockAwareOperation
 
LockAwareOperation(String, Data, Data) - Constructor for class com.hazelcast.map.impl.operation.LockAwareOperation
 
LockBackupOperation - Class in com.hazelcast.internal.locksupport.operations
 
LockBackupOperation() - Constructor for class com.hazelcast.internal.locksupport.operations.LockBackupOperation
 
LockBackupOperation(ObjectNamespace, Data, long, long, UUID, boolean) - Constructor for class com.hazelcast.internal.locksupport.operations.LockBackupOperation
 
lockClusterState(ClusterStateChange, Address, UUID, long, int, int) - Method in class com.hazelcast.internal.cluster.impl.ClusterStateManager
Validates the requested cluster state change and sets a ClusterStateLock.
LockClusterStateOp - Class in com.hazelcast.internal.cluster.impl.operations
 
LockClusterStateOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.LockClusterStateOp
 
LockClusterStateOp(ClusterStateChange, Address, UUID, long, int, int) - Constructor for class com.hazelcast.internal.cluster.impl.operations.LockClusterStateOp
 
lockCount - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockGetLockOwnershipCodec.ResponseParameters
TODO DOC
LockDataSerializerHook - Class in com.hazelcast.cp.internal.datastructures.lock
 
LockDataSerializerHook() - Constructor for class com.hazelcast.cp.internal.datastructures.lock.LockDataSerializerHook
 
LockDataSerializerHook - Class in com.hazelcast.internal.locksupport
 
LockDataSerializerHook() - Constructor for class com.hazelcast.internal.locksupport.LockDataSerializerHook
 
LockEndpoint - Class in com.hazelcast.cp.internal.datastructures.lock
LockEndpoint represents a thread in a Raft client.
LockEndpoint() - Constructor for class com.hazelcast.cp.internal.datastructures.lock.LockEndpoint
 
LockEndpoint(long, long) - Constructor for class com.hazelcast.cp.internal.datastructures.lock.LockEndpoint
 
LockEvictionProcessor - Class in com.hazelcast.internal.locksupport
 
LockEvictionProcessor(NodeEngine, ObjectNamespace) - Constructor for class com.hazelcast.internal.locksupport.LockEvictionProcessor
 
lockForDirectory(File, ILogger) - Static method in class com.hazelcast.internal.util.DirectoryLock
Acquires a lock for given directory.
LockGuard - Class in com.hazelcast.internal.util
Object that provides additional functionalities to a simple lock.
LockGuard(Address, UUID, long) - Constructor for class com.hazelcast.internal.util.LockGuard
 
LockInterceptorService<T> - Interface in com.hazelcast.internal.services
Interface to be implemented by services that need to intercept lock operation for distributed objects it manages.
lockInterruptibly() - Method in class com.hazelcast.client.cp.internal.datastructures.lock.FencedLockProxy
 
lockInterruptibly() - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
lockInterruptibly() - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock unless the current thread is interrupted.
LockInvocationKey - Class in com.hazelcast.cp.internal.datastructures.lock
Represents lock() invocation of a LockEndpoint.
LockInvocationKey() - Constructor for class com.hazelcast.cp.internal.datastructures.lock.LockInvocationKey
 
LockInvocationKey(long, UUID, Address, long, LockEndpoint) - Constructor for class com.hazelcast.cp.internal.datastructures.lock.LockInvocationKey
 
LockMessageTask - Class in com.hazelcast.cp.internal.datastructures.lock.client
Client message task for LockOp
LockMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.lock.client.LockMessageTask
 
LockOp - Class in com.hazelcast.cp.internal.datastructures.lock.operation
Operation for FencedLock.lock()
LockOp() - Constructor for class com.hazelcast.cp.internal.datastructures.lock.operation.LockOp
 
LockOp(String, long, long, UUID) - Constructor for class com.hazelcast.cp.internal.datastructures.lock.operation.LockOp
 
LockOperation - Class in com.hazelcast.internal.locksupport.operations
 
LockOperation() - Constructor for class com.hazelcast.internal.locksupport.operations.LockOperation
 
LockOperation(ObjectNamespace, Data, long, long, long) - Constructor for class com.hazelcast.internal.locksupport.operations.LockOperation
 
LockOperation(ObjectNamespace, Data, long, long, long, long, boolean) - Constructor for class com.hazelcast.internal.locksupport.operations.LockOperation
 
LockOwnershipLostException - Exception in com.hazelcast.cp.lock.exception
Thrown when an endpoint (either a Hazelcast server or a client) interacts with a FencedLock instance after its CP session is closed in the underlying CP group and its lock ownership is cancelled.
LockOwnershipLostException() - Constructor for exception com.hazelcast.cp.lock.exception.LockOwnershipLostException
 
LockOwnershipLostException(String) - Constructor for exception com.hazelcast.cp.lock.exception.LockOwnershipLostException
 
LockOwnershipState - Class in com.hazelcast.cp.internal.datastructures.lock
Represents ownership state of a Raft Lock
LockOwnershipState() - Constructor for class com.hazelcast.cp.internal.datastructures.lock.LockOwnershipState
 
LockOwnershipState(long, int, long, long) - Constructor for class com.hazelcast.cp.internal.datastructures.lock.LockOwnershipState
 
LockPermission - Class in com.hazelcast.security.permission
 
LockPermission(String, String...) - Constructor for class com.hazelcast.security.permission.LockPermission
 
LockProxySupport - Class in com.hazelcast.internal.locksupport
 
LockProxySupport(ObjectNamespace, long) - Constructor for class com.hazelcast.internal.locksupport.LockProxySupport
 
LockReplicationOperation - Class in com.hazelcast.internal.locksupport.operations
 
LockReplicationOperation() - Constructor for class com.hazelcast.internal.locksupport.operations.LockReplicationOperation
 
LockReplicationOperation(LockStoreContainer, int, int) - Constructor for class com.hazelcast.internal.locksupport.operations.LockReplicationOperation
 
LockReplicationOperation(LockStoreContainer, int, int, Collection<ServiceNamespace>) - Constructor for class com.hazelcast.internal.locksupport.operations.LockReplicationOperation
 
LockResource - Interface in com.hazelcast.internal.locksupport
A lock for a specific key in a specific namespace.
LockService - Class in com.hazelcast.cp.internal.datastructures.lock
Contains Raft-based lock instances
LockService(NodeEngine) - Constructor for class com.hazelcast.cp.internal.datastructures.lock.LockService
 
LockStore - Interface in com.hazelcast.internal.locksupport
A container for multiple locks.
LockStoreContainer - Class in com.hazelcast.internal.locksupport
 
LockStoreContainer(LockSupportServiceImpl, int) - Constructor for class com.hazelcast.internal.locksupport.LockStoreContainer
 
LockStoreImpl - Class in com.hazelcast.internal.locksupport
 
LockStoreImpl() - Constructor for class com.hazelcast.internal.locksupport.LockStoreImpl
 
LockStoreImpl(LockSupportService, ObjectNamespace, EntryTaskScheduler<Data, Integer>, int, int) - Constructor for class com.hazelcast.internal.locksupport.LockStoreImpl
 
LockStoreInfo - Interface in com.hazelcast.internal.locksupport
 
LockStoreProxy - Class in com.hazelcast.internal.locksupport
Proxy to a LockStoreImpl.
LockStoreProxy(LockStoreContainer, ObjectNamespace) - Constructor for class com.hazelcast.internal.locksupport.LockStoreProxy
 
lockSupport - Variable in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
LockSupportService - Interface in com.hazelcast.internal.locksupport
 
LockSupportServiceImpl - Class in com.hazelcast.internal.locksupport
 
LockSupportServiceImpl(NodeEngine) - Constructor for class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
LockWaitNotifyKey - Class in com.hazelcast.internal.locksupport
 
LockWaitNotifyKey(ObjectNamespace, Data) - Constructor for class com.hazelcast.internal.locksupport.LockWaitNotifyKey
 
log() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns the Raft log
log(AuditableEvent) - Method in interface com.hazelcast.internal.auditlog.AuditlogService
Logs given event.
log(String, Level, String) - Method in interface com.hazelcast.internal.auditlog.AuditlogService
Creates and logs a simple parameterless message at the given level.
log(String, Level, String, Throwable) - Method in interface com.hazelcast.internal.auditlog.AuditlogService
Creates and logs a simple parameterless message with an associated throwable at the given level.
log() - Method in interface com.hazelcast.internal.auditlog.EventBuilder
Builds the event and logs it to the service which provided this builder (if any).
log() - Method in class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService.Builder
 
log(AuditableEvent) - Method in class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService
 
log(String, Level, String) - Method in class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService
 
log(String, Level, String, Throwable) - Method in class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService
 
log(Event) - Method in class com.hazelcast.internal.management.ManagementCenterService
Logs an event to Management Center and calls the configured ManagementCenterEventListener with the logged event if it is set.
log(Throwable, ILogger) - Static method in class com.hazelcast.internal.partition.ReplicaErrorLogger
 
log(Level, String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at the given level.
log(Level, String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the given level.
log(LogEvent) - Method in interface com.hazelcast.logging.ILogger
Logs a LogEvent.
log(LogEvent) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
log(Level, String) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
log(Level, String, Throwable) - Method in class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
log(LogEvent) - Method in interface com.hazelcast.logging.LogListener
 
log(Level, String) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
log(Level, String, String) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
log(Level, String, String, Throwable) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
log2(int) - Static method in class com.hazelcast.internal.util.QuickMath
Return the log 2 result for this int.
log2(long) - Static method in class com.hazelcast.internal.util.QuickMath
Return the log 2 result for this long.
Log4j2Factory - Class in com.hazelcast.logging
Logging to Log4j 2.x.
Log4j2Factory() - Constructor for class com.hazelcast.logging.Log4j2Factory
 
Log4j2Factory.Log4j2Logger - Class in com.hazelcast.logging
 
Log4j2Logger(ExtendedLogger) - Constructor for class com.hazelcast.logging.Log4j2Factory.Log4j2Logger
 
Log4jFactory - Class in com.hazelcast.logging
 
Log4jFactory() - Constructor for class com.hazelcast.logging.Log4jFactory
 
LOG_ENTRY - Static variable in class com.hazelcast.cp.internal.raft.impl.RaftDataSerializerHook
 
LOG_PARTITIONS - Static variable in class com.hazelcast.internal.diagnostics.SystemLogPlugin
If logging partition migration is enabled.
logAllExceptions(ILogger, String, Level) - Static method in class com.hazelcast.internal.util.FutureUtil
This ExceptionHandler rethrows ExecutionExceptions and logs MemberLeftExceptions to the log.
logAllExceptions(String, Level) - Static method in class com.hazelcast.internal.util.FutureUtil
This ExceptionHandler rethrows ExecutionExceptions and logs MemberLeftExceptions to the log.
logAllExceptions(ILogger, Level) - Static method in class com.hazelcast.internal.util.FutureUtil
This ExceptionHandler rethrows ExecutionExceptions and logs MemberLeftExceptions to the log.
logAllExceptions(Level) - Static method in class com.hazelcast.internal.util.FutureUtil
This ExceptionHandler rethrows ExecutionExceptions and logs MemberLeftExceptions to the log.
logAttempt(E) - Method in class com.hazelcast.internal.cluster.fd.PingFailureDetector
 
LogEntry - Class in com.hazelcast.cp.internal.raft.impl.log
Represents an entry in the RaftLog.
LogEntry() - Constructor for class com.hazelcast.cp.internal.raft.impl.log.LogEntry
 
LogEntry(int, long, Object) - Constructor for class com.hazelcast.cp.internal.raft.impl.log.LogEntry
 
logError(Throwable) - Method in class com.hazelcast.cache.impl.operation.CacheClearExpiredOperation
 
logError(Throwable) - Method in class com.hazelcast.cache.impl.operation.CacheOperation
 
logError(Throwable) - Method in class com.hazelcast.internal.cluster.impl.operations.CommitClusterStateOp
 
logError(Throwable) - Method in class com.hazelcast.internal.cluster.impl.operations.LockClusterStateOp
 
logError(Throwable) - Method in class com.hazelcast.internal.partition.operation.PartitionBackupReplicaAntiEntropyOperation
 
logError(Throwable) - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRequest
 
logError(Throwable) - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncResponse
 
logError(Throwable) - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRetryResponse
 
logError(Throwable) - Method in class com.hazelcast.map.impl.operation.MapClearExpiredOperation
 
logError(Throwable) - Method in class com.hazelcast.map.impl.operation.MapOperation
 
logError(Throwable) - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
 
logError(Throwable) - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
 
logError(Throwable) - Method in class com.hazelcast.ringbuffer.impl.operations.AbstractRingBufferOperation
 
logError(Throwable) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
 
logError(Throwable) - Method in class com.hazelcast.spi.impl.operationservice.Operation
Logs Exception/Error thrown during operation execution.
LogEvent - Class in com.hazelcast.logging
 
LogEvent(LogRecord, Member) - Constructor for class com.hazelcast.logging.LogEvent
 
LogFileStructure - Class in com.hazelcast.cp.internal.raft.impl.persistence
Used in the EE side
LogFileStructure(String, long[], long) - Constructor for class com.hazelcast.cp.internal.raft.impl.persistence.LogFileStructure
 
logger - Variable in class com.hazelcast.cache.impl.AbstractCacheService
 
LOGGER - Static variable in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
 
LOGGER - Static variable in class com.hazelcast.client.impl.clientside.DefaultClientExtension
 
logger - Variable in class com.hazelcast.client.impl.connection.ClientConnectionStrategy
 
logger - Variable in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
logger - Variable in class com.hazelcast.collection.impl.collection.CollectionContainer
 
logger - Variable in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
logger - Variable in class com.hazelcast.cp.internal.raft.impl.task.RaftNodeStatusAwareTask
 
logger - Variable in class com.hazelcast.instance.impl.DefaultNodeExtension
 
logger - Variable in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
logger - Variable in class com.hazelcast.internal.diagnostics.DiagnosticsPlugin
 
logger - Variable in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationMetaDataFetcher
 
logger - Variable in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
 
logger - Variable in class com.hazelcast.internal.networking.AbstractChannel
 
logger - Variable in class com.hazelcast.internal.networking.nio.NioPipeline
 
Logger - Class in com.hazelcast.logging
Provides static utilities to access the global shared logging machinery.
logger - Variable in class com.hazelcast.map.impl.query.PartitionScanRunner
 
logger - Variable in class com.hazelcast.map.impl.query.QueryRunner
 
logger - Variable in class com.hazelcast.map.impl.querycache.accumulator.BasicAccumulator
 
logger - Variable in class com.hazelcast.map.impl.querycache.subscriber.AbstractQueryCacheEndToEndConstructor
 
logger - Variable in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
logger - Variable in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
logger - Variable in class com.hazelcast.topic.impl.reliable.MessageRunner
 
LoggerFactory - Interface in com.hazelcast.logging
 
LoggerFactorySupport - Class in com.hazelcast.logging
 
LoggerFactorySupport() - Constructor for class com.hazelcast.logging.LoggerFactorySupport
 
LOGGING_TYPE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
LoggingScheduledExecutor - Class in com.hazelcast.internal.util.executor
LoggingScheduledExecutor(ILogger, int, ThreadFactory) - Constructor for class com.hazelcast.internal.util.executor.LoggingScheduledExecutor
 
LoggingScheduledExecutor(ILogger, int, ThreadFactory, RejectedExecutionHandler) - Constructor for class com.hazelcast.internal.util.executor.LoggingScheduledExecutor
 
loggingService - Variable in class com.hazelcast.instance.impl.Node
 
loggingService(LoggingService) - Method in class com.hazelcast.internal.networking.nio.NioNetworking.Context
 
LoggingService - Interface in com.hazelcast.logging
 
LoggingServiceImpl - Class in com.hazelcast.logging.impl
 
LoggingServiceImpl(String, String, BuildInfo) - Constructor for class com.hazelcast.logging.impl.LoggingServiceImpl
 
LOGIN - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
LoginModuleConfig - Class in com.hazelcast.config
Configuration for Login Module
LoginModuleConfig() - Constructor for class com.hazelcast.config.LoginModuleConfig
 
LoginModuleConfig(String, LoginModuleConfig.LoginModuleUsage) - Constructor for class com.hazelcast.config.LoginModuleConfig
 
LoginModuleConfig.LoginModuleUsage - Enum in com.hazelcast.config
Usage of Login Module
LogListener - Interface in com.hazelcast.logging
 
LogValidationException - Exception in com.hazelcast.cp.internal.raft.exception
Thrown when a validation error occurs while restoring a Raft log from persistent storage.
LogValidationException(String) - Constructor for exception com.hazelcast.cp.internal.raft.exception.LogValidationException
 
Long2LongHashMap - Class in com.hazelcast.internal.util.collection
A Probing hashmap specialised for long key and value pairs.
Long2LongHashMap(int, double, long) - Constructor for class com.hazelcast.internal.util.collection.Long2LongHashMap
 
Long2LongHashMap(long) - Constructor for class com.hazelcast.internal.util.collection.Long2LongHashMap
 
Long2LongHashMap(Long2LongHashMap) - Constructor for class com.hazelcast.internal.util.collection.Long2LongHashMap
 
Long2LongHashMap.LongIterator - Class in com.hazelcast.internal.util.collection
Adds an unboxed next() method to the standard Iterator interface.
Long2LongHashMap.LongLongCursor - Class in com.hazelcast.internal.util.collection
Implements the cursor.
Long2LongMap - Interface in com.hazelcast.internal.util.collection
A map that uses primitive longs for both key and value.
Long2LongMapHsa - Class in com.hazelcast.internal.util.collection
a Long2LongMap implemented in terms of a HashSlotArray8byteKey.
Long2LongMapHsa(long, MemoryManager) - Constructor for class com.hazelcast.internal.util.collection.Long2LongMapHsa
 
Long2ObjectHashMap<V> - Class in com.hazelcast.internal.util.collection
Map implementation specialised for long keys using open addressing and linear probing for cache efficient access.
Long2ObjectHashMap() - Constructor for class com.hazelcast.internal.util.collection.Long2ObjectHashMap
 
Long2ObjectHashMap(int) - Constructor for class com.hazelcast.internal.util.collection.Long2ObjectHashMap
 
Long2ObjectHashMap(int, double) - Constructor for class com.hazelcast.internal.util.collection.Long2ObjectHashMap
Construct a new map allowing a configuration for initial capacity and load factor.
Long2ObjectHashMap.KeyIterator - Class in com.hazelcast.internal.util.collection
Adds an unboxed next() method to the standard Iterator interface.
Long2ObjectHashMap.KeySet - Class in com.hazelcast.internal.util.collection
Adds non-boxing methods to the standard Set interface.
LONG_AVG - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
LONG_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
LONG_SIZE_IN_BYTES - Static variable in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
LONG_SIZE_IN_BYTES - Static variable in class com.hazelcast.internal.nio.Bits
Long size in bytes
LONG_SUM - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
LongArrayCodec - Class in com.hazelcast.client.impl.protocol.codec.builtin
 
LongArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.LongArraySerializer
 
LongAverageAggregator<I> - Class in com.hazelcast.aggregation.impl
 
LongAverageAggregator() - Constructor for class com.hazelcast.aggregation.impl.LongAverageAggregator
 
LongAverageAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.LongAverageAggregator
 
longAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
longAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
LongCursor - Interface in com.hazelcast.internal.util.collection
Cursor over a collection of long values.
longForEach(LongLongConsumer) - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
Primitive specialised forEach implementation.
LongGauge - Interface in com.hazelcast.internal.metrics
A LongGauge is a Gauge where a particular long value is read instantaneously.
LongHashSet - Class in com.hazelcast.internal.util.collection
Simple fixed-size long hashset.
LongHashSet(int, long) - Constructor for class com.hazelcast.internal.util.collection.LongHashSet
 
LongHashSet(long[], long) - Constructor for class com.hazelcast.internal.util.collection.LongHashSet
 
LongIterator - Class in com.hazelcast.internal.util.collection
An iterator for a sequence of primitive integers.
LongIterator(long, long[]) - Constructor for class com.hazelcast.internal.util.collection.LongIterator
Construct an Iterator over an array of primitives longs.
LongLongConsumer - Interface in com.hazelcast.internal.util.function
This is a (long,long) primitive specialisation of a BiConsumer
LongLongCursor() - Constructor for class com.hazelcast.internal.util.collection.Long2LongHashMap.LongLongCursor
 
LongLongCursor - Interface in com.hazelcast.internal.util.collection
Cursor over the entries of a primitive long-to-long map.
longMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
longMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
LongMemArrayQuickSorter - Class in com.hazelcast.internal.util.sort
QuickSorter implementation for a memory block which stores an array of ints.
LongMemArrayQuickSorter(MemoryAccessor, long) - Constructor for class com.hazelcast.internal.util.sort.LongMemArrayQuickSorter
 
longMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
longMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
LongProbeFunction<S> - Interface in com.hazelcast.internal.metrics
A ProbeFunction that provides a long value and can be used to create a probe using MetricsRegistry.registerStaticProbe(Object, String, ProbeLevel, LongProbeFunction)
LongRegister - Class in com.hazelcast.internal.longregister
 
LongRegister() - Constructor for class com.hazelcast.internal.longregister.LongRegister
 
LongRegisterAddAndGetCodec - Class in com.hazelcast.internal.longregister.client.codec
Atomically adds the given value to the current value.
LongRegisterAddAndGetCodec.RequestParameters - Class in com.hazelcast.internal.longregister.client.codec
 
LongRegisterAddAndGetCodec.ResponseParameters - Class in com.hazelcast.internal.longregister.client.codec
 
LongRegisterAddAndGetMessageTask - Class in com.hazelcast.internal.longregister.client.task
 
LongRegisterAddAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.internal.longregister.client.task.LongRegisterAddAndGetMessageTask
 
LongRegisterBackupAwareOperation - Class in com.hazelcast.internal.longregister.operations
 
LongRegisterBackupAwareOperation() - Constructor for class com.hazelcast.internal.longregister.operations.LongRegisterBackupAwareOperation
 
LongRegisterBackupAwareOperation(String) - Constructor for class com.hazelcast.internal.longregister.operations.LongRegisterBackupAwareOperation
 
LongRegisterDataSerializerHook - Class in com.hazelcast.internal.longregister
 
LongRegisterDataSerializerHook() - Constructor for class com.hazelcast.internal.longregister.LongRegisterDataSerializerHook
 
LongRegisterDecrementAndGetCodec - Class in com.hazelcast.internal.longregister.client.codec
Atomically decrements the current value by one.
LongRegisterDecrementAndGetCodec.RequestParameters - Class in com.hazelcast.internal.longregister.client.codec
 
LongRegisterDecrementAndGetCodec.ResponseParameters - Class in com.hazelcast.internal.longregister.client.codec
 
LongRegisterDecrementAndGetMessageTask - Class in com.hazelcast.internal.longregister.client.task
 
LongRegisterDecrementAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.internal.longregister.client.task.LongRegisterDecrementAndGetMessageTask
 
LongRegisterGetAndAddCodec - Class in com.hazelcast.internal.longregister.client.codec
Atomically adds the given value to the current value.
LongRegisterGetAndAddCodec.RequestParameters - Class in com.hazelcast.internal.longregister.client.codec
 
LongRegisterGetAndAddCodec.ResponseParameters - Class in com.hazelcast.internal.longregister.client.codec
 
LongRegisterGetAndAddMessageTask - Class in com.hazelcast.internal.longregister.client.task
 
LongRegisterGetAndAddMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndAddMessageTask
 
LongRegisterGetAndIncrementCodec - Class in com.hazelcast.internal.longregister.client.codec
Atomically increments the current value by one.
LongRegisterGetAndIncrementCodec.RequestParameters - Class in com.hazelcast.internal.longregister.client.codec
 
LongRegisterGetAndIncrementCodec.ResponseParameters - Class in com.hazelcast.internal.longregister.client.codec
 
LongRegisterGetAndIncrementMessageTask - Class in com.hazelcast.internal.longregister.client.task
 
LongRegisterGetAndIncrementMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndIncrementMessageTask
 
LongRegisterGetAndSetCodec - Class in com.hazelcast.internal.longregister.client.codec
Atomically sets the given value and returns the old value.
LongRegisterGetAndSetCodec.RequestParameters - Class in com.hazelcast.internal.longregister.client.codec
 
LongRegisterGetAndSetCodec.ResponseParameters - Class in com.hazelcast.internal.longregister.client.codec
 
LongRegisterGetAndSetMessageTask - Class in com.hazelcast.internal.longregister.client.task
 
LongRegisterGetAndSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndSetMessageTask
 
LongRegisterGetCodec - Class in com.hazelcast.internal.longregister.client.codec
Gets the current value.
LongRegisterGetCodec.RequestParameters - Class in com.hazelcast.internal.longregister.client.codec
 
LongRegisterGetCodec.ResponseParameters - Class in com.hazelcast.internal.longregister.client.codec
 
LongRegisterGetMessageTask - Class in com.hazelcast.internal.longregister.client.task
 
LongRegisterGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.internal.longregister.client.task.LongRegisterGetMessageTask
 
LongRegisterIncrementAndGetCodec - Class in com.hazelcast.internal.longregister.client.codec
Atomically increments the current value by one.
LongRegisterIncrementAndGetCodec.RequestParameters - Class in com.hazelcast.internal.longregister.client.codec
 
LongRegisterIncrementAndGetCodec.ResponseParameters - Class in com.hazelcast.internal.longregister.client.codec
 
LongRegisterIncrementAndGetMessageTask - Class in com.hazelcast.internal.longregister.client.task
 
LongRegisterIncrementAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.internal.longregister.client.task.LongRegisterIncrementAndGetMessageTask
 
LongRegisterProxy - Class in com.hazelcast.internal.longregister
Partially implements IAtomicLong.
LongRegisterProxy(String, NodeEngine, LongRegisterService) - Constructor for class com.hazelcast.internal.longregister.LongRegisterProxy
 
LongRegisterReplicationOperation - Class in com.hazelcast.internal.longregister.operations
 
LongRegisterReplicationOperation() - Constructor for class com.hazelcast.internal.longregister.operations.LongRegisterReplicationOperation
 
LongRegisterReplicationOperation(Map<String, Long>) - Constructor for class com.hazelcast.internal.longregister.operations.LongRegisterReplicationOperation
 
LongRegisterService - Class in com.hazelcast.internal.longregister
 
LongRegisterService(NodeEngine) - Constructor for class com.hazelcast.internal.longregister.LongRegisterService
 
LongRegisterServiceDescriptorProvider - Class in com.hazelcast.internal.longregister
 
LongRegisterServiceDescriptorProvider() - Constructor for class com.hazelcast.internal.longregister.LongRegisterServiceDescriptorProvider
 
LongRegisterSetCodec - Class in com.hazelcast.internal.longregister.client.codec
Atomically sets the given value.
LongRegisterSetCodec.RequestParameters - Class in com.hazelcast.internal.longregister.client.codec
 
LongRegisterSetCodec.ResponseParameters - Class in com.hazelcast.internal.longregister.client.codec
 
LongRegisterSetMessageTask - Class in com.hazelcast.internal.longregister.client.task
 
LongRegisterSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.internal.longregister.client.task.LongRegisterSetMessageTask
 
LongSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.LongSerializer
 
LongSet - Interface in com.hazelcast.internal.util.collection
Set of primitive longs.
LongSetHsa - Class in com.hazelcast.internal.util.collection
LongSet implementation based on HashSlotArray8byteKey.
LongSetHsa(long, MemoryManager) - Constructor for class com.hazelcast.internal.util.collection.LongSetHsa
 
LongSetHsa(long, MemoryManager, int, float) - Constructor for class com.hazelcast.internal.util.collection.LongSetHsa
 
longSum() - Static method in class com.hazelcast.aggregation.Aggregators
 
longSum(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
LongSumAggregator<I> - Class in com.hazelcast.aggregation.impl
 
LongSumAggregator() - Constructor for class com.hazelcast.aggregation.impl.LongSumAggregator
 
LongSumAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.LongSumAggregator
 
longToByteArray(long) - Static method in class com.hazelcast.internal.ascii.memcache.MemcacheCommandProcessor
 
lookupByPattern(ConfigPatternMatcher, Map<String, T>, String) - Static method in class com.hazelcast.internal.config.ConfigUtils
 
lookupClassDefinition(int, int, int) - Method in interface com.hazelcast.internal.serialization.PortableContext
 
lookupClassDefinition(Data) - Method in interface com.hazelcast.internal.serialization.PortableContext
 
lookupNamespaceURI(String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
lookupOrRegisterClassDefinition(Portable) - Method in interface com.hazelcast.internal.serialization.PortableContext
 
lookupPrefix(String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
lowerCaseFirstChar(String) - Static method in class com.hazelcast.internal.util.StringUtil
Converts the first character to lower case.
lowerCaseInternal(String) - Static method in class com.hazelcast.internal.util.StringUtil
HC specific settings, operands etc.
LRU_EVICTION_POLICY - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
LRUEvictionPolicy - Class in com.hazelcast.map.eviction
LRU eviction policy for an IMap
LRUEvictionPolicy() - Constructor for class com.hazelcast.map.eviction.LRUEvictionPolicy
 
LRUEvictionPolicyComparator - Class in com.hazelcast.internal.eviction.impl.comparator
LRUEvictionPolicyComparator() - Constructor for class com.hazelcast.internal.eviction.impl.comparator.LRUEvictionPolicyComparator
 

M

MADE_PUBLISHABLE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MADE_PUBLISHABLE_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MadePublishableOperation - Class in com.hazelcast.map.impl.querycache.subscriber.operation
MadePublishableOperation() - Constructor for class com.hazelcast.map.impl.querycache.subscriber.operation.MadePublishableOperation
 
MadePublishableOperation(String, String) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.operation.MadePublishableOperation
 
MadePublishableOperationFactory - Class in com.hazelcast.map.impl.querycache.subscriber.operation
Operation factory for MadePublishableOperation.
MadePublishableOperationFactory() - Constructor for class com.hazelcast.map.impl.querycache.subscriber.operation.MadePublishableOperationFactory
 
MadePublishableOperationFactory(String, String) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.operation.MadePublishableOperationFactory
 
main(String[]) - Static method in class com.hazelcast.client.console.ClientConsoleApp
Starts the test application.
main(String...) - Static method in class com.hazelcast.config.replacer.EncryptionReplacer
 
main(String[]) - Static method in class com.hazelcast.console.ConsoleApp
Starts the test application.
main(String[]) - Static method in class com.hazelcast.core.server.StartServer
Creates a server instance of Hazelcast.
mainConnectionExists() - Method in interface com.hazelcast.client.impl.connection.nio.ClusterConnectorService
 
mainConnectionExists() - Method in class com.hazelcast.client.impl.connection.nio.ClusterConnectorServiceImpl
 
MAJOR_MINOR_VERSION_COMPARATOR - Static variable in class com.hazelcast.version.MemberVersion
Version comparator that takes into account only major & minor version, disregarding patch version number.
majority() - Method in class com.hazelcast.cp.internal.raft.impl.state.CandidateState
Returns the number of expected majority of the votes.
majority() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftGroupMembers
Returns the majority for this group.
majority() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns majority number of the last applied group members
majorityAppendRequestAckTimestamp(int) - Method in class com.hazelcast.cp.internal.raft.impl.state.LeaderState
Returns the earliest append response ack timestamp of the majority nodes
makeTimestamp() - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
makeTimestamp() - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
makeTimestamp() - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Returns a new timestamp.
malloc() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
ManagedAnnotation - Annotation Type in com.hazelcast.internal.jmx
Annotation for management bean attributes.
ManagedContext - Interface in com.hazelcast.core
Container managed context, such as Spring, Guice and etc.
managedContext - Variable in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
managedContext - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
ManagedDescription - Annotation Type in com.hazelcast.internal.jmx
Annotation for management bean descriptions.
ManagedExecutorDTO - Class in com.hazelcast.internal.management.dto
A Serializable DTO for ManagedExecutorServiceMBean.
ManagedExecutorDTO() - Constructor for class com.hazelcast.internal.management.dto.ManagedExecutorDTO
 
ManagedExecutorDTO(ManagedExecutorService) - Constructor for class com.hazelcast.internal.management.dto.ManagedExecutorDTO
 
ManagedExecutorService - Interface in com.hazelcast.internal.util.executor
 
ManagedExecutorServiceMBean - Class in com.hazelcast.internal.jmx
Management bean for ManagedExecutorService
ManagedExecutorServiceMBean(HazelcastInstance, ManagedExecutorService, ManagementService) - Constructor for class com.hazelcast.internal.jmx.ManagedExecutorServiceMBean
 
managedObject - Variable in class com.hazelcast.internal.jmx.HazelcastMBean
 
ManagedService - Interface in com.hazelcast.internal.services
An interface that can be implemented by an SPI Service to receive lifecycle calls: initialization shutdown reset
managedService - Variable in class com.hazelcast.map.impl.MapService
 
ManagedThread(Runnable, String, int) - Constructor for class com.hazelcast.internal.util.executor.PoolExecutorThreadFactory.ManagedThread
 
ManagedTransactionalTaskContext - Class in com.hazelcast.spring.transaction
TransactionalTaskContext proxying implementation to make the one created by HazelcastTransactionManager available to actual business logic.
ManagedTransactionalTaskContext(HazelcastTransactionManager) - Constructor for class com.hazelcast.spring.transaction.ManagedTransactionalTaskContext
 
MANAGEMENT_CONFIG - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
MANAGEMENT_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
MANAGEMENT_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ManagementCenterConfig - Class in com.hazelcast.config
Contains the configuration for a Management Center.
ManagementCenterConfig() - Constructor for class com.hazelcast.config.ManagementCenterConfig
 
ManagementCenterConfig(String, int) - Constructor for class com.hazelcast.config.ManagementCenterConfig
 
ManagementCenterConnectionFactory - Interface in com.hazelcast.internal.management
 
ManagementCenterEventListener - Interface in com.hazelcast.internal.management
Callback interface that captures Events logged to Management Center.
ManagementCenterPublisher - Class in com.hazelcast.internal.metrics.managementcenter
Renderer to serialize metrics to byte[] to be read by Management Center.
ManagementCenterPublisher(LoggingService, ObjLongConsumer<byte[]>) - Constructor for class com.hazelcast.internal.metrics.managementcenter.ManagementCenterPublisher
 
ManagementCenterService - Class in com.hazelcast.internal.management
ManagementCenterService is responsible for sending statistics data to the Management Center.
ManagementCenterService(HazelcastInstanceImpl) - Constructor for class com.hazelcast.internal.management.ManagementCenterService
 
ManagementCenterService.MemberListenerImpl - Class in com.hazelcast.internal.management
MembershipListener to send Management Center URL to the new members.
ManagementDataSerializerHook - Class in com.hazelcast.internal.management
 
ManagementDataSerializerHook() - Constructor for class com.hazelcast.internal.management.ManagementDataSerializerHook
 
managementEnabled - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
true to enable management interface on this cache or false
ManagementService - Class in com.hazelcast.internal.jmx
Service responsible for registering hazelcast management beans to the platform management bean server.
ManagementService(HazelcastInstanceImpl) - Constructor for class com.hazelcast.internal.jmx.ManagementService
 
ManyToOneConcurrentArrayQueue<E> - Class in com.hazelcast.internal.util.concurrent
Many producers to single consumer concurrent queue backed by an array.
ManyToOneConcurrentArrayQueue(int) - Constructor for class com.hazelcast.internal.util.concurrent.ManyToOneConcurrentArrayQueue
 
map(List<AliasedDiscoveryConfig<?>>) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Maps aliased discovery strategy configs into discovery strategy configs.
map(Iterable<T>, Function<T, R>) - Static method in class com.hazelcast.internal.util.IterableUtil
Transform the Iterable by applying a function to each element
map(Iterator<T>, Function<T, R>) - Static method in class com.hazelcast.internal.util.IterableUtil
Transform the Iterator by applying a function to each element
map - Variable in class com.hazelcast.map.impl.iterator.AbstractMapPartitionIterator
 
map - Variable in class com.hazelcast.map.impl.iterator.AbstractMapQueryPartitionIterator
 
MAP_ASSIGN_AND_GET_UUIDS - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MAP_ASSIGN_AND_GET_UUIDS_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MAP_ATTRIBUTE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MAP_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MAP_CONFIG_DTO - Static variable in class com.hazelcast.internal.management.ManagementDataSerializerHook
 
MAP_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
MAP_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
MAP_ENTRIES - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
 
MAP_ENTRY_EVENT - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
 
MAP_EVICTION_BATCH_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Maximum number of IMap entries Hazelcast will evict during a single eviction cycle.
MAP_EXPIRY_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
You can use MAP_EXPIRY_DELAY_SECONDS to deal with some possible edge cases, such as using EntryProcessor.
MAP_FLUSH_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MAP_GET_ALL_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MAP_INDEX_INFO - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MAP_INVALIDATION_MESSAGE_BATCH_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines Near Cache invalidation event batch sending is enabled or not.
MAP_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines the Near Cache invalidation event batch sending frequency in seconds.
MAP_INVALIDATION_MESSAGE_BATCH_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines the maximum number of Near Cache invalidation events to be drained and sent to the event Near Cache in a batch.
MAP_INVALIDATION_METADATA - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MAP_INVALIDATION_METADATA_RESPONSE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MAP_KEY_SET - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
 
MAP_LISTENER_TO_ENTRY_LISTENER_ADAPTER - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MAP_LOAD_ALL_KEYS_EXECUTOR - Static variable in interface com.hazelcast.spi.impl.executionservice.ExecutionService
The name of the executor that loads the entry keys and dispatches the keys to the partition owners for value loading.
MAP_LOAD_CHUNK_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
The maximum size of the key batch sent to the partition owners for value loading and the maximum size of a key batch for which values are loaded in a single partition.
MAP_LOADER_EXECUTOR - Static variable in interface com.hazelcast.spi.impl.executionservice.ExecutionService
Name of the map-loader executor that loads the entry values for a given key set locally on the member owning the partition which contains the keys.
MAP_MERGING_ENTRY - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
MAP_NAME_PREFIX - Static variable in class com.hazelcast.internal.ascii.memcache.MemcacheCommandProcessor
 
MAP_NEAR_CACHE_STATE_HOLDER - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MAP_PARTITION_LOST_EVENT - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
 
MAP_PARTITION_LOST_LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MAP_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
MAP_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
MAP_REDUCE_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
MAP_REDUCE_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
MAP_REPLICA_SCHEDULED_TASK_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
MAP_REPLICATION - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MAP_REPLICATION_REMOVE - Static variable in class com.hazelcast.wan.impl.WanDataSerializerHook
 
MAP_REPLICATION_STATE_HOLDER - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MAP_REPLICATION_UPDATE - Static variable in class com.hazelcast.wan.impl.WanDataSerializerHook
 
MAP_STORE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MAP_TRANSACTION_LOG_RECORD - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MAP_WRITE_BEHIND_QUEUE_CAPACITY - Static variable in class com.hazelcast.spi.properties.GroupProperty
Setting this capacity is valid if you set MapStoreConfig.writeCoalescing to false.
MapAddEntryListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a MapListener for this map.
MapAddEntryListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddEntryListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddEntryListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddEntryListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapAddEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerMessageTask
 
MapAddEntryListenerToKeyCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a MapListener for this map.
MapAddEntryListenerToKeyCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddEntryListenerToKeyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddEntryListenerToKeyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddEntryListenerToKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapAddEntryListenerToKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyMessageTask
 
MapAddEntryListenerToKeyWithPredicateCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a MapListener for this map.
MapAddEntryListenerToKeyWithPredicateCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddEntryListenerToKeyWithPredicateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddEntryListenerToKeyWithPredicateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddEntryListenerToKeyWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapAddEntryListenerToKeyWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyWithPredicateMessageTask
 
MapAddEntryListenerWithPredicateCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds an continuous entry listener for this map.
MapAddEntryListenerWithPredicateCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddEntryListenerWithPredicateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddEntryListenerWithPredicateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddEntryListenerWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapAddEntryListenerWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerWithPredicateMessageTask
 
MapAddIndexCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds an index to this map with specified configuration.
MapAddIndexCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddIndexCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddIndexMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapAddIndexMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAddIndexMessageTask
 
MapAddInterceptorCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds an interceptor for this map.
MapAddInterceptorCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddInterceptorCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddInterceptorMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapAddInterceptorMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAddInterceptorMessageTask
 
MapAddListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ContinuousQueryMessageType#CONTINUOUSQUERY_ADDLISTENER
MapAddListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAddListenerMessageTask
 
MapAddNearCacheEntryListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds an entry listener for this map.
MapAddNearCacheEntryListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddNearCacheEntryListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddNearCacheEntryListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddNearCacheInvalidationListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds listener to map.
MapAddNearCacheInvalidationListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddNearCacheInvalidationListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddNearCacheInvalidationListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddNearCacheInvalidationListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
Clients which are AWARE of eventual consistent Near Cache should call this task.
MapAddNearCacheInvalidationListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAddNearCacheInvalidationListenerMessageTask
 
MapAddPartitionLostListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a MapPartitionLostListener.
MapAddPartitionLostListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddPartitionLostListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddPartitionLostListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAddPartitionLostListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapAddPartitionLostListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
 
MapAggregateCodec - Class in com.hazelcast.client.impl.protocol.codec
Applies the aggregation logic on all map entries and returns the result
MapAggregateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAggregateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAggregateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapAggregateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAggregateMessageTask
 
MapAggregateWithPredicateCodec - Class in com.hazelcast.client.impl.protocol.codec
Applies the aggregation logic on map entries filtered with the Predicate and returns the result
MapAggregateWithPredicateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAggregateWithPredicateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAggregateWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapAggregateWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAggregateWithPredicateMessageTask
 
MapAssignAndGetUuidsCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
MapAssignAndGetUuidsCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAssignAndGetUuidsCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapAssignAndGetUuidsMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapAssignAndGetUuidsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsMessageTask
 
MapAssignAndGetUuidsOperation - Class in com.hazelcast.client.impl.protocol.task.map
 
MapAssignAndGetUuidsOperation() - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsOperation
 
MapAssignAndGetUuidsOperationFactory - Class in com.hazelcast.client.impl.protocol.task.map
 
MapAssignAndGetUuidsOperationFactory() - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsOperationFactory
 
MapClearCodec - Class in com.hazelcast.client.impl.protocol.codec
This method clears the map and invokes MapStore#deleteAll deleteAll on MapStore which, if connected to a database, will delete the records from that database.
MapClearCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapClearCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
mapCleared(MapEvent) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
mapCleared(MapEvent) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
 
mapCleared(MapEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
mapCleared(MapEvent) - Method in class com.hazelcast.console.ConsoleApp
 
mapCleared(MapEvent) - Method in class com.hazelcast.core.EntryAdapter
 
mapCleared(MapEvent) - Method in class com.hazelcast.map.impl.MapListenerAdapter
 
mapCleared(MapEvent) - Method in interface com.hazelcast.map.listener.MapClearedListener
Invoked when all entries are removed by IMap.clear().
MapClearedListener - Interface in com.hazelcast.map.listener
Invoked after all entries are removed by IMap.clear().
MapClearExpiredOperation - Class in com.hazelcast.map.impl.operation
Clears expired records.
MapClearExpiredOperation(int) - Constructor for class com.hazelcast.map.impl.operation.MapClearExpiredOperation
 
MapClearExpiredRecordsTask - Class in com.hazelcast.map.impl.eviction
Clears expired entries (TTL & idle).
MapClearExpiredRecordsTask(PartitionContainer[], NodeEngine) - Constructor for class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
 
MapClearMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapClearMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapClearMessageTask
 
MapClearNearCacheCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
MapClearNearCacheCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapClearNearCacheCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapCodec - Class in com.hazelcast.client.impl.protocol.codec.builtin
 
MapConfig - Class in com.hazelcast.config
Contains the configuration for an IMap.
MapConfig() - Constructor for class com.hazelcast.config.MapConfig
 
MapConfig(String) - Constructor for class com.hazelcast.config.MapConfig
 
MapConfig(MapConfig) - Constructor for class com.hazelcast.config.MapConfig
 
mapConfig - Variable in class com.hazelcast.map.impl.MapContainer
 
MapConfigDTO - Class in com.hazelcast.internal.management.dto
Serializable adapter for MapConfig
MapConfigDTO() - Constructor for class com.hazelcast.internal.management.dto.MapConfigDTO
 
MapConfigDTO(MapConfig) - Constructor for class com.hazelcast.internal.management.dto.MapConfigDTO
 
MapConfigReadOnly - Class in com.hazelcast.internal.config
Contains the configuration for an IMap (read-only).
MapConfigReadOnly(MapConfig) - Constructor for class com.hazelcast.internal.config.MapConfigReadOnly
 
MapConfigRequest - Class in com.hazelcast.internal.management.request
Request for updating map configuration from Management Center.
MapConfigRequest() - Constructor for class com.hazelcast.internal.management.request.MapConfigRequest
 
MapConfigRequest(String, MapConfigDTO, boolean) - Constructor for class com.hazelcast.internal.management.request.MapConfigRequest
 
MapContainer - Class in com.hazelcast.map.impl
Map container for a map with a specific name.
MapContainer(String, Config, MapServiceContext) - Constructor for class com.hazelcast.map.impl.MapContainer
Operations which are done in this constructor should obey the rules defined in the method comment PostJoinAwareService.getPostJoinOperation() Otherwise undesired situations, like deadlocks, may appear.
mapContainer - Variable in class com.hazelcast.map.impl.operation.MapOperation
 
MapContainsKeyCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns true if this map contains a mapping for the specified key.
MapContainsKeyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapContainsKeyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapContainsKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapContainsKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapContainsKeyMessageTask
 
MapContainsValueCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns true if this map maps one or more keys to the specified value.This operation will probably require time linear in the map size for most implementations of the Map interface.
MapContainsValueCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapContainsValueCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapContainsValueMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapContainsValueMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapContainsValueMessageTask
 
MapDataSerializerHook - Class in com.hazelcast.map.impl
 
MapDataSerializerHook() - Constructor for class com.hazelcast.map.impl.MapDataSerializerHook
 
MapDataStore<K,V> - Interface in com.hazelcast.map.impl.mapstore
Map data stores general contract.
MapDataStores - Class in com.hazelcast.map.impl.mapstore
Factory class responsible for creating various data store implementations.
MapDelegatingSet<V> - Class in com.hazelcast.internal.util.collection
Read-only collection which delegates its operations to an underlying map and a couple of functions.
MapDelegatingSet(Map<?, ?>, Supplier<Iterator<V>>, Predicate) - Constructor for class com.hazelcast.internal.util.collection.MapDelegatingSet
 
MapDeleteCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the mapping for a key from this map if it is present.Unlike remove(Object), this operation does not return the removed value, which avoids the serialization cost of the returned value.If the removed value will not be used, a delete operation is preferred over a remove operation for better performance.
MapDeleteCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapDeleteCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapDeleteMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapDeleteMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapDeleteMessageTask
 
MapDestroyCacheMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ContinuousQueryMessageType#CONTINUOUSQUERY_DESTROYCACHE
MapDestroyCacheMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapDestroyCacheMessageTask
 
mapDrainIterator(int, Map<Long, Data>) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
 
MapEntries - Class in com.hazelcast.map.impl
MapEntries is a collection of Data instances for keys and values of a Map.Entry.
MapEntries() - Constructor for class com.hazelcast.map.impl.MapEntries
 
MapEntries(int) - Constructor for class com.hazelcast.map.impl.MapEntries
 
MapEntries(List<Map.Entry<Data, Data>>) - Constructor for class com.hazelcast.map.impl.MapEntries
 
mapEntries - Variable in class com.hazelcast.map.impl.operation.PutAllPartitionAwareOperationFactory
 
MapEntriesWithCursor - Class in com.hazelcast.map.impl.iterator
Container class for a collection of entries along with an offset from which new entries can be fetched.
MapEntriesWithCursor() - Constructor for class com.hazelcast.map.impl.iterator.MapEntriesWithCursor
 
MapEntriesWithCursor(List<Map.Entry<Data, Data>>, int) - Constructor for class com.hazelcast.map.impl.iterator.MapEntriesWithCursor
 
MapEntriesWithPagingPredicateCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
MapEntriesWithPagingPredicateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapEntriesWithPagingPredicateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapEntriesWithPagingPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapEntriesWithPagingPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPagingPredicateMessageTask
 
MapEntriesWithPredicateCodec - Class in com.hazelcast.client.impl.protocol.codec
Queries the map based on the specified predicate and returns the matching entries.Specified predicate runs on all members in parallel.
MapEntriesWithPredicateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapEntriesWithPredicateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapEntriesWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapEntriesWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPredicateMessageTask
 
MapEntrySetCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns a Set clone of the mappings contained in this map.
MapEntrySetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapEntrySetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapEntrySetMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapEntrySetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapEntrySetMessageTask
 
MapEntrySimple<K,V> - Class in com.hazelcast.map.impl
 
MapEntrySimple(K, V) - Constructor for class com.hazelcast.map.impl.MapEntrySimple
 
MapEvent - Class in com.hazelcast.map
Used for map-wide events like EntryEventType.EVICT_ALL and EntryEventType.CLEAR_ALL.
MapEvent(Object, Member, int, int) - Constructor for class com.hazelcast.map.MapEvent
 
MapEventData - Class in com.hazelcast.map.impl.event
Map wide event's data.
MapEventData() - Constructor for class com.hazelcast.map.impl.event.MapEventData
 
MapEventData(String, String, Address, int, int) - Constructor for class com.hazelcast.map.impl.event.MapEventData
 
MapEventJournal - Interface in com.hazelcast.map.impl.journal
The event journal is a container for events related to a data structure.
MapEventJournalFunctions - Class in com.hazelcast.map.impl.journal
Utility functions used from Jet.
MapEventJournalReadCodec - Class in com.hazelcast.client.impl.protocol.codec
Reads from the map event journal in batches.
MapEventJournalReadCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapEventJournalReadCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapEventJournalReadOperation<K,V,T> - Class in com.hazelcast.map.impl.journal
Reads from the map event journal in batches.
MapEventJournalReadOperation() - Constructor for class com.hazelcast.map.impl.journal.MapEventJournalReadOperation
 
MapEventJournalReadOperation(String, long, int, int, Predicate<? super EventJournalMapEvent<K, V>>, Function<? super EventJournalMapEvent<K, V>, ? extends T>) - Constructor for class com.hazelcast.map.impl.journal.MapEventJournalReadOperation
 
MapEventJournalReadResultSetImpl<K,V,T> - Class in com.hazelcast.map.impl.journal
 
MapEventJournalReadResultSetImpl() - Constructor for class com.hazelcast.map.impl.journal.MapEventJournalReadResultSetImpl
 
MapEventJournalReadTask<K,V,T> - Class in com.hazelcast.client.impl.protocol.task.map
Reads from the map event journal in batches.
MapEventJournalReadTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapEventJournalReadTask
 
MapEventJournalSubscribeCodec - Class in com.hazelcast.client.impl.protocol.codec
Performs the initial subscription to the map event journal.
MapEventJournalSubscribeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapEventJournalSubscribeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapEventJournalSubscribeOperation - Class in com.hazelcast.map.impl.journal
Performs the initial subscription to the map event journal.
MapEventJournalSubscribeOperation() - Constructor for class com.hazelcast.map.impl.journal.MapEventJournalSubscribeOperation
 
MapEventJournalSubscribeOperation(String) - Constructor for class com.hazelcast.map.impl.journal.MapEventJournalSubscribeOperation
 
MapEventJournalSubscribeTask - Class in com.hazelcast.client.impl.protocol.task.map
Performs the initial subscription to the map event journal.
MapEventJournalSubscribeTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapEventJournalSubscribeTask
 
mapEventNewValue() - Static method in class com.hazelcast.map.impl.journal.MapEventJournalFunctions
 
MapEventPublisher - Interface in com.hazelcast.map.impl.event
Helper methods for publishing events related to map actions.
mapEventPublisher - Variable in class com.hazelcast.map.impl.operation.MapOperation
 
mapEventPublisher - Variable in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
MapEventPublisherImpl - Class in com.hazelcast.map.impl.event
 
MapEventPublisherImpl(MapServiceContext) - Constructor for class com.hazelcast.map.impl.event.MapEventPublisherImpl
 
MapEventPublishingService - Class in com.hazelcast.map.impl.event
Contains map service event publishing service functionality.
MapEventPublishingService(MapServiceContext) - Constructor for class com.hazelcast.map.impl.event.MapEventPublishingService
 
mapEventToEntry() - Static method in class com.hazelcast.map.impl.journal.MapEventJournalFunctions
 
MapEvictAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Evicts all keys from this map except the locked ones.
MapEvictAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapEvictAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapEvictAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapEvictAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapEvictAllMessageTask
 
MapEvictCodec - Class in com.hazelcast.client.impl.protocol.codec
Evicts the specified key from this map.
MapEvictCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapEvictCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
mapEvicted(MapEvent) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
mapEvicted(MapEvent) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
 
mapEvicted(MapEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
mapEvicted(MapEvent) - Method in class com.hazelcast.console.ConsoleApp
 
mapEvicted(MapEvent) - Method in class com.hazelcast.core.EntryAdapter
 
mapEvicted(MapEvent) - Method in class com.hazelcast.map.impl.MapListenerAdapter
 
mapEvicted(MapEvent) - Method in interface com.hazelcast.map.listener.MapEvictedListener
Invoked when all entries are evicted by IMap.evictAll().
MapEvictedListener - Interface in com.hazelcast.map.listener
Invoked after all entries are evicted by IMap.evictAll().
mapEvictionPolicy - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
custom com.hazelcast.map.eviction.MapEvictionPolicy implementation or null
MapEvictionPolicy<K,V> - Class in com.hazelcast.map.eviction
An eviction policy takes its role after the decision that a map needs to free some memory according to one of MaxSizePolicies and it helps to find most appropriate entries to remove.
MapEvictionPolicy() - Constructor for class com.hazelcast.map.eviction.MapEvictionPolicy
 
mapEvictionPolicy - Variable in class com.hazelcast.map.impl.eviction.EvictorImpl
 
MapEvictMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapEvictMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapEvictMessageTask
 
MapExecuteOnAllKeysCodec - Class in com.hazelcast.client.impl.protocol.codec
Applies the user defined EntryProcessor to the all entries in the map.Returns the results mapped by each key in the map.
MapExecuteOnAllKeysCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapExecuteOnAllKeysCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapExecuteOnAllKeysMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapExecuteOnAllKeysMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnAllKeysMessageTask
 
MapExecuteOnKeyCodec - Class in com.hazelcast.client.impl.protocol.codec
Applies the user defined EntryProcessor to the entry mapped by the key.
MapExecuteOnKeyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapExecuteOnKeyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapExecuteOnKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapExecuteOnKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeyMessageTask
 
MapExecuteOnKeysCodec - Class in com.hazelcast.client.impl.protocol.codec
Applies the user defined EntryProcessor to the entries mapped by the collection of keys.The results mapped by each key in the collection.
MapExecuteOnKeysCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapExecuteOnKeysCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapExecuteOnKeysMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapExecuteOnKeysMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeysMessageTask
 
MapExecuteWithPredicateCodec - Class in com.hazelcast.client.impl.protocol.codec
Applies the user defined EntryProcessor to the entries in the map which satisfies provided predicate.
MapExecuteWithPredicateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapExecuteWithPredicateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapExecuteWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapExecuteWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapExecuteWithPredicateMessageTask
 
MapFetchEntriesCodec - Class in com.hazelcast.client.impl.protocol.codec
Fetches specified number of entries from the specified partition starting from specified table index.
MapFetchEntriesCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapFetchEntriesCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapFetchEntriesMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapFetchEntriesMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapFetchEntriesMessageTask
 
MapFetchEntriesOperation - Class in com.hazelcast.map.impl.operation
Operation for fetching a chunk of entries from a single IMap partition.
MapFetchEntriesOperation() - Constructor for class com.hazelcast.map.impl.operation.MapFetchEntriesOperation
 
MapFetchEntriesOperation(String, int, int) - Constructor for class com.hazelcast.map.impl.operation.MapFetchEntriesOperation
 
MapFetchKeysCodec - Class in com.hazelcast.client.impl.protocol.codec
Fetches specified number of keys from the specified partition starting from specified table index.
MapFetchKeysCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapFetchKeysCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapFetchKeysMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapFetchKeysMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapFetchKeysMessageTask
 
MapFetchKeysOperation - Class in com.hazelcast.map.impl.operation
Operation for fetching a chunk of keys from a single IMap partition.
MapFetchKeysOperation() - Constructor for class com.hazelcast.map.impl.operation.MapFetchKeysOperation
 
MapFetchKeysOperation(String, int, int) - Constructor for class com.hazelcast.map.impl.operation.MapFetchKeysOperation
 
MapFetchNearCacheInvalidationMetadataCodec - Class in com.hazelcast.client.impl.protocol.codec
Fetches invalidation metadata from partitions of map.
MapFetchNearCacheInvalidationMetadataCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapFetchNearCacheInvalidationMetadataCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapFetchNearCacheInvalidationMetadataTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapFetchNearCacheInvalidationMetadataTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapFetchNearCacheInvalidationMetadataTask
 
MapFetchWithQueryCodec - Class in com.hazelcast.client.impl.protocol.codec
Fetches the specified number of entries from the specified partition starting from specified table index that match the predicate and applies the projection logic on them.
MapFetchWithQueryCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapFetchWithQueryCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapFetchWithQueryMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
Fetches by query a batch of items from a single partition ID for a map.
MapFetchWithQueryMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapFetchWithQueryMessageTask
 
MapFetchWithQueryOperation - Class in com.hazelcast.map.impl.operation
Fetches by query a batch of fetchSize items from a single partition ID for a map.
MapFetchWithQueryOperation() - Constructor for class com.hazelcast.map.impl.operation.MapFetchWithQueryOperation
 
MapFetchWithQueryOperation(String, int, int, Query) - Constructor for class com.hazelcast.map.impl.operation.MapFetchWithQueryOperation
 
MapFlushBackupOperation - Class in com.hazelcast.map.impl.operation
Empties backup write-behind-queues upon IMap.flush()
MapFlushBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.MapFlushBackupOperation
 
MapFlushBackupOperation(String) - Constructor for class com.hazelcast.map.impl.operation.MapFlushBackupOperation
 
MapFlushCodec - Class in com.hazelcast.client.impl.protocol.codec
If this map has a MapStore, this method flushes all the local dirty entries by calling MapStore.storeAll() and/or MapStore.deleteAll().
MapFlushCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapFlushCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapFlushMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapFlushMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
 
MapFlushOperation - Class in com.hazelcast.map.impl.operation
Flushes dirty entries upon call of IMap.flush()
MapFlushOperation() - Constructor for class com.hazelcast.map.impl.operation.MapFlushOperation
 
MapFlushOperation(String) - Constructor for class com.hazelcast.map.impl.operation.MapFlushOperation
 
MapFlushOperationFactory - Class in com.hazelcast.map.impl.operation
 
MapFlushOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.MapFlushOperationFactory
 
MapFlushOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.MapFlushOperationFactory
 
MapFlushWaitNotifyKey - Class in com.hazelcast.map.impl.operation
Key used to notify end of IMap.flush() operation.
MapFlushWaitNotifyKey(String, int, long) - Constructor for class com.hazelcast.map.impl.operation.MapFlushWaitNotifyKey
 
MapForceUnlockCodec - Class in com.hazelcast.client.impl.protocol.codec
Releases the lock for the specified key regardless of the lock owner.It always successfully unlocks the key, never blocks,and returns immediately.
MapForceUnlockCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapForceUnlockCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapForceUnlockMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapForceUnlockMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
 
MapGetAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the entries for the given keys.
MapGetAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapGetAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapGetAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapGetAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
 
MapGetAllOperationFactory - Class in com.hazelcast.map.impl.operation
 
MapGetAllOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.MapGetAllOperationFactory
 
MapGetAllOperationFactory(String, List<Data>) - Constructor for class com.hazelcast.map.impl.operation.MapGetAllOperationFactory
 
MapGetCodec - Class in com.hazelcast.client.impl.protocol.codec
This method returns a clone of the original value, so modifying the returned value does not change the actual value in the map.
MapGetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapGetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapGetEntryViewCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the EntryView for the specified key.
MapGetEntryViewCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapGetEntryViewCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapGetEntryViewMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapGetEntryViewMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapGetEntryViewMessageTask
 
MapGetInvalidationMetaDataOperation - Class in com.hazelcast.map.impl.operation
 
MapGetInvalidationMetaDataOperation() - Constructor for class com.hazelcast.map.impl.operation.MapGetInvalidationMetaDataOperation
 
MapGetInvalidationMetaDataOperation(List<String>) - Constructor for class com.hazelcast.map.impl.operation.MapGetInvalidationMetaDataOperation
 
MapGetInvalidationMetaDataOperation.MetaDataResponse - Class in com.hazelcast.map.impl.operation
 
MapGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
 
MapIndexInfo - Class in com.hazelcast.query.impl
 
MapIndexInfo(String) - Constructor for class com.hazelcast.query.impl.MapIndexInfo
 
MapIndexInfo() - Constructor for class com.hazelcast.query.impl.MapIndexInfo
 
mapIndexInfos - Variable in class com.hazelcast.map.impl.operation.MapReplicationStateHolder
 
MapInterceptor - Interface in com.hazelcast.map
MapInterceptor is used to intercept changes to the map, allowing access to the values before and after adding them to the map.
MapIsEmptyCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns true if this map contains no key-value mappings.
MapIsEmptyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapIsEmptyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapIsEmptyMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapIsEmptyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
 
MapIsEmptyOperation - Class in com.hazelcast.map.impl.operation
 
MapIsEmptyOperation(String) - Constructor for class com.hazelcast.map.impl.operation.MapIsEmptyOperation
 
MapIsEmptyOperation() - Constructor for class com.hazelcast.map.impl.operation.MapIsEmptyOperation
 
MapIsLockedCodec - Class in com.hazelcast.client.impl.protocol.codec
Checks the lock for the specified key.If the lock is acquired then returns true, else returns false.
MapIsLockedCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapIsLockedCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapIsLockedMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapIsLockedMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
 
mapIterateAndRemove(Map<Long, Data>) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Deletes items from the queue which have IDs contained in the key set of the given map.
MapKeyLoader - Class in com.hazelcast.map.impl
Loads keys from a MapLoader and sends them to all partitions for loading
MapKeyLoader(String, OperationService, IPartitionService, ClusterService, ExecutionService, Function<Object, Data>) - Constructor for class com.hazelcast.map.impl.MapKeyLoader
 
MapKeyLoaderUtil - Class in com.hazelcast.map.impl
 
MapKeySet - Class in com.hazelcast.map.impl
 
MapKeySet(Set<Data>) - Constructor for class com.hazelcast.map.impl.MapKeySet
 
MapKeySet() - Constructor for class com.hazelcast.map.impl.MapKeySet
 
MapKeySetCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns a set clone of the keys contained in this map.
MapKeySetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapKeySetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapKeySetMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapKeySetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
 
MapKeySetWithPagingPredicateCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
MapKeySetWithPagingPredicateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapKeySetWithPagingPredicateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapKeySetWithPagingPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapKeySetWithPagingPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
 
MapKeySetWithPredicateCodec - Class in com.hazelcast.client.impl.protocol.codec
Queries the map based on the specified predicate and returns the keys of matching entries.
MapKeySetWithPredicateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapKeySetWithPredicateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapKeySetWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapKeySetWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
 
MapKeysWithCursor - Class in com.hazelcast.map.impl.iterator
Container class for a collection of keys along with an offset from which new keys can be fetched.
MapKeysWithCursor() - Constructor for class com.hazelcast.map.impl.iterator.MapKeysWithCursor
 
MapKeysWithCursor(List<Data>, int) - Constructor for class com.hazelcast.map.impl.iterator.MapKeysWithCursor
 
MapListener - Interface in com.hazelcast.map.listener
A marker interface which is used to get notified upon a map or an entry event.
MapListenerAdapter<K,V> - Class in com.hazelcast.map.impl
Internal usage only adapter for MapListener.
MapListenerAdapter() - Constructor for class com.hazelcast.map.impl.MapListenerAdapter
 
MapListenerAdaptors - Class in com.hazelcast.map.impl
A static factory class which creates various ListenerAdapter implementations.
MapListenerFlagOperator - Class in com.hazelcast.map.impl
Contains helper methods to set bit flags of implemented listener interfaces of a MapListener.
MapListenerRegistry - Class in com.hazelcast.map.impl.querycache.publisher
Holds QueryCacheListenerRegistry for each IMap.
MapListenerRegistry(QueryCacheContext) - Constructor for class com.hazelcast.map.impl.querycache.publisher.MapListenerRegistry
 
MapListenerToEntryListenerAdapter() - Constructor for class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
MapListenerToEntryListenerAdapter(MapListener) - Constructor for class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
MapLoadAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Loads all keys into the store.
MapLoadAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapLoadAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapLoadAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapLoadAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
 
MapLoadAllOperationFactory - Class in com.hazelcast.map.impl.operation
Operation factory for load all operations.
MapLoadAllOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.MapLoadAllOperationFactory
 
MapLoadAllOperationFactory(String, List<Data>, boolean) - Constructor for class com.hazelcast.map.impl.operation.MapLoadAllOperationFactory
 
MapLoader<K,V> - Interface in com.hazelcast.map
Hazelcast distributed map implementation is an in-memory data store but it can be backed by any type of data store such as RDBMS, OODBMS, or simply a file based data store.
MapLoaderLifecycleSupport - Interface in com.hazelcast.map
Provides Lifecycle support for the implementing MapLoader class.
MapLoadGivenKeysCodec - Class in com.hazelcast.client.impl.protocol.codec
Loads the given keys.
MapLoadGivenKeysCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapLoadGivenKeysCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapLoadGivenKeysMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapLoadGivenKeysMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
 
MapLockCodec - Class in com.hazelcast.client.impl.protocol.codec
Acquires the lock for the specified lease time.After lease time, lock will be released.If the lock is not available then the current thread becomes disabled for thread scheduling purposes and lies dormant until the lock has been acquired.
MapLockCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapLockCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapLockMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapLockMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
 
MapMadePublishableMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ContinuousQueryMessageType#CONTINUOUSQUERY_MADEPUBLISHABLE
MapMadePublishableMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapMadePublishableMessageTask
 
MapManagedService - Class in com.hazelcast.map.impl
Defines managed service behavior of map service.
MapMBean - Class in com.hazelcast.internal.jmx
Management bean for IMap
MapMBean(IMap, ManagementService) - Constructor for class com.hazelcast.internal.jmx.MapMBean
 
MapMergingEntryImpl - Class in com.hazelcast.spi.impl.merge
MapMergingEntryImpl() - Constructor for class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
MapMergingEntryImpl(SerializationService) - Constructor for class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
mapName - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryDestroyCacheCodec.RequestParameters
Name of the map.
mapName - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryMadePublishableCodec.RequestParameters
Name of the map.
mapName - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateCodec.RequestParameters
Name of the map.
mapName - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateWithValueCodec.RequestParameters
Name of the map.
mapName - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQuerySetReadCursorCodec.RequestParameters
Name of the map.
mapName(String) - Method in class com.hazelcast.map.impl.query.Query.QueryBuilder
 
mapName - Variable in class com.hazelcast.map.impl.querycache.subscriber.AbstractQueryCacheEndToEndConstructor
 
MapNameAndKeyPair - Class in com.hazelcast.internal.ascii.memcache
Value object for (mapName, key) pair
MapNameAndKeyPair(String, String) - Constructor for class com.hazelcast.internal.ascii.memcache.MapNameAndKeyPair
 
mapNameSequencePairs - Variable in class com.hazelcast.map.impl.operation.MapNearCacheStateHolder
 
MapNearCacheManager - Class in com.hazelcast.map.impl.nearcache
 
MapNearCacheManager(MapServiceContext) - Constructor for class com.hazelcast.map.impl.nearcache.MapNearCacheManager
 
mapNearCacheManager - Variable in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
 
MapNearCacheStateHolder - Class in com.hazelcast.map.impl.operation
Holder for Near Cache metadata.
MapNearCacheStateHolder() - Constructor for class com.hazelcast.map.impl.operation.MapNearCacheStateHolder
This constructor exists solely for instantiation by MapDataSerializerHook.
MapNearCacheStateHolder(MapReplicationOperation) - Constructor for class com.hazelcast.map.impl.operation.MapNearCacheStateHolder
 
mapNearCacheStateHolder - Variable in class com.hazelcast.map.impl.operation.MapReplicationOperation
 
MapOperation - Class in com.hazelcast.map.impl.operation
 
MapOperation() - Constructor for class com.hazelcast.map.impl.operation.MapOperation
 
MapOperation(String) - Constructor for class com.hazelcast.map.impl.operation.MapOperation
 
MapOperationProvider - Interface in com.hazelcast.map.impl.operation
Provides InMemoryFormat specific operations for IMap.
MapOperationProviders - Class in com.hazelcast.map.impl.operation
A central place to ask for MapOperationProvider instance by map name.
MapOperationProviders() - Constructor for class com.hazelcast.map.impl.operation.MapOperationProviders
 
MapPartitionDestroyOperation - Class in com.hazelcast.map.impl.operation
Operation to destroy the map data on the partition thread
MapPartitionDestroyOperation(PartitionContainer, MapContainer) - Constructor for class com.hazelcast.map.impl.operation.MapPartitionDestroyOperation
 
MapPartitionEventData - Class in com.hazelcast.map.impl.event
Contains the data related to a map partition event
MapPartitionEventData() - Constructor for class com.hazelcast.map.impl.event.MapPartitionEventData
 
MapPartitionEventData(String, String, Address, int) - Constructor for class com.hazelcast.map.impl.event.MapPartitionEventData
 
MapPartitionIterator<K,V> - Class in com.hazelcast.map.impl.iterator
Iterator for iterating map entries in the partitionId.
MapPartitionIterator(MapProxyImpl<K, V>, int, int, boolean) - Constructor for class com.hazelcast.map.impl.iterator.MapPartitionIterator
 
MapPartitionLostEvent - Class in com.hazelcast.map
Used for providing information about the lost partition for a map
MapPartitionLostEvent(Object, Member, int, int) - Constructor for class com.hazelcast.map.MapPartitionLostEvent
 
MapPartitionLostEventFilter - Class in com.hazelcast.map.impl
 
MapPartitionLostEventFilter() - Constructor for class com.hazelcast.map.impl.MapPartitionLostEventFilter
 
MapPartitionLostListener - Interface in com.hazelcast.map.listener
Invoked when owner and all backups of a partition is lost for a specific map.
MapPartitionLostListenerConfig - Class in com.hazelcast.config
Configuration for MapPartitionLostListener
MapPartitionLostListenerConfig() - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
 
MapPartitionLostListenerConfig(String) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
 
MapPartitionLostListenerConfig(MapPartitionLostListener) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
 
MapPartitionLostListenerConfig(MapPartitionLostListenerConfig) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
 
MapPartitionLostListenerConfigReadOnly - Class in com.hazelcast.internal.config
Read-Only Configuration for MapPartitionLostListener
MapPartitionLostListenerConfigReadOnly(MapPartitionLostListenerConfig) - Constructor for class com.hazelcast.internal.config.MapPartitionLostListenerConfigReadOnly
 
MapPermission - Class in com.hazelcast.security.permission
 
MapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.MapPermission
 
MapPortableHook - Class in com.hazelcast.map.impl.client
Portable serialization hook for Map structures.
MapPortableHook() - Constructor for class com.hazelcast.map.impl.client.MapPortableHook
 
MapProjectCodec - Class in com.hazelcast.client.impl.protocol.codec
Applies the projection logic on all map entries and returns the result
MapProjectCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapProjectCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapProjectionMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapProjectionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapProjectionMessageTask
 
MapProjectionWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapProjectionWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapProjectionWithPredicateMessageTask
 
MapProjectWithPredicateCodec - Class in com.hazelcast.client.impl.protocol.codec
Applies the projection logic on map entries filtered with the Predicate and returns the result
MapProjectWithPredicateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapProjectWithPredicateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapProxyImpl<K,V> - Class in com.hazelcast.map.impl.proxy
Proxy implementation of IMap interface.
MapProxyImpl(String, MapService, NodeEngine, MapConfig) - Constructor for class com.hazelcast.map.impl.proxy.MapProxyImpl
 
MapPublisherCreateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ContinuousQueryMessageType#CONTINUOUSQUERY_PUBLISHERCREATE
MapPublisherCreateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateMessageTask
 
MapPublisherCreateWithValueMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ContinuousQueryMessageType#CONTINUOUSQUERY_PUBLISHERCREATEWITHVALUE
MapPublisherCreateWithValueMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapPublisherCreateWithValueMessageTask
 
MapPublisherRegistry - Class in com.hazelcast.map.impl.querycache.publisher
Registry of mappings like mapName to PublisherRegistry.
MapPublisherRegistry(QueryCacheContext) - Constructor for class com.hazelcast.map.impl.querycache.publisher.MapPublisherRegistry
 
MapPutAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Copies all of the mappings from the specified map to this map (optional operation).The effect of this call is equivalent to that of calling put(Object,Object) put(k, v) on this map once for each mapping from key k to value v in the specified map.The behavior of this operation is undefined if the specified map is modified while the operation is in progress.
MapPutAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapPutAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapPutAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapPutAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
 
MapPutCodec - Class in com.hazelcast.client.impl.protocol.codec
Puts an entry into this map with a given ttl (time to live) value.Entry will expire and get evicted after the ttl If ttl is 0, then the entry lives forever.This method returns a clone of the previous value, not the original (identically equal) value previously put into the map.Time resolution for TTL is seconds.
MapPutCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapPutCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
mapPutEvents() - Static method in class com.hazelcast.map.impl.journal.MapEventJournalFunctions
 
MapPutIfAbsentCodec - Class in com.hazelcast.client.impl.protocol.codec
Puts an entry into this map with a given ttl (time to live) value if the specified key is not already associated with a value.
MapPutIfAbsentCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapPutIfAbsentCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapPutIfAbsentMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapPutIfAbsentMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentMessageTask
 
MapPutIfAbsentWithMaxIdleCodec - Class in com.hazelcast.client.impl.protocol.codec
Puts an entry into this map with a given ttl (time to live) value if the specified key is not already associated with a value.
MapPutIfAbsentWithMaxIdleCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapPutIfAbsentWithMaxIdleCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapPutIfAbsentWithMaxIdleMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapPutIfAbsentWithMaxIdleMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentWithMaxIdleMessageTask
 
MapPutMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapPutMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapPutMessageTask
 
MapPutTransientCodec - Class in com.hazelcast.client.impl.protocol.codec
Same as put except that MapStore, if defined, will not be called to store/persist the entry.
MapPutTransientCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapPutTransientCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapPutTransientMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapPutTransientMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapPutTransientMessageTask
 
MapPutTransientWithMaxIdleCodec - Class in com.hazelcast.client.impl.protocol.codec
Same as put except that MapStore, if defined, will not be called to store/persist the entry.
MapPutTransientWithMaxIdleCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapPutTransientWithMaxIdleCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapPutTransientWithMaxIdleMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapPutTransientWithMaxIdleMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapPutTransientWithMaxIdleMessageTask
 
MapPutWithMaxIdleCodec - Class in com.hazelcast.client.impl.protocol.codec
Puts an entry into this map with a given ttl (time to live) value.Entry will expire and get evicted after the ttl If ttl is 0, then the entry lives forever.This method returns a clone of the previous value, not the original (identically equal) value previously put into the map.Time resolution for TTL is seconds.
MapPutWithMaxIdleCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapPutWithMaxIdleCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapPutWithMaxIdleMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapPutWithMaxIdleMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapPutWithMaxIdleMessageTask
 
MapQueryPartitionIterator<K,V,R> - Class in com.hazelcast.map.impl.iterator
Iterator for iterating map entries in the partitionId.
MapQueryPartitionIterator(MapProxyImpl<K, V>, int, int, Predicate<K, V>, Projection<? super Map.Entry<K, V>, R>) - Constructor for class com.hazelcast.map.impl.iterator.MapQueryPartitionIterator
 
MapRecordKey - Class in com.hazelcast.map.impl
 
MapRecordKey(String, Data) - Constructor for class com.hazelcast.map.impl.MapRecordKey
 
MapRemoveAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes all entries which match with the supplied predicate
MapRemoveAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapRemoveAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapRemoveAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapRemoveAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapRemoveAllMessageTask
 
MapRemoveCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the mapping for a key from this map if it is present (optional operation).
MapRemoveCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapRemoveCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapRemoveEntryListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the specified entry listener.
MapRemoveEntryListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapRemoveEntryListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapRemoveEntryListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapRemoveEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapRemoveEntryListenerMessageTask
 
MapRemoveIfSameCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the mapping for a key from this map if existing value equal to the this value
MapRemoveIfSameCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapRemoveIfSameCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapRemoveIfSameMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapRemoveIfSameMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapRemoveIfSameMessageTask
 
MapRemoveInterceptorCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the given interceptor for this map so it will not intercept operations anymore.
MapRemoveInterceptorCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapRemoveInterceptorCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapRemoveInterceptorMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapRemoveInterceptorMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
 
MapRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
 
MapRemovePartitionLostListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the specified map partition lost listener.
MapRemovePartitionLostListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapRemovePartitionLostListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapRemovePartitionLostListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapRemovePartitionLostListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapRemovePartitionLostListenerMessageTask
 
MapReplaceCodec - Class in com.hazelcast.client.impl.protocol.codec
Replaces the entry for a key only if currently mapped to a given value.
MapReplaceCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapReplaceCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapReplaceIfSameCodec - Class in com.hazelcast.client.impl.protocol.codec
Replaces the the entry for a key only if existing values equal to the testValue
MapReplaceIfSameCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapReplaceIfSameCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapReplaceIfSameMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapReplaceIfSameMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapReplaceIfSameMessageTask
 
MapReplaceMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapReplaceMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapReplaceMessageTask
 
MapReplicationOperation - Class in com.hazelcast.map.impl.operation
Replicates all IMap-states of this partition to a repReservedCapacityCounterTestlica partition.
MapReplicationOperation() - Constructor for class com.hazelcast.map.impl.operation.MapReplicationOperation
 
MapReplicationOperation(PartitionContainer, int, int) - Constructor for class com.hazelcast.map.impl.operation.MapReplicationOperation
 
MapReplicationOperation(PartitionContainer, Collection<ServiceNamespace>, int, int) - Constructor for class com.hazelcast.map.impl.operation.MapReplicationOperation
 
MapReplicationRemove - Class in com.hazelcast.map.impl.wan
 
MapReplicationRemove(String, Data) - Constructor for class com.hazelcast.map.impl.wan.MapReplicationRemove
 
MapReplicationRemove() - Constructor for class com.hazelcast.map.impl.wan.MapReplicationRemove
 
mapReplicationStateHolder - Variable in class com.hazelcast.map.impl.operation.MapReplicationOperation
 
MapReplicationStateHolder - Class in com.hazelcast.map.impl.operation
Holder for raw IMap key-value pairs and their metadata.
MapReplicationStateHolder() - Constructor for class com.hazelcast.map.impl.operation.MapReplicationStateHolder
This constructor exists solely for instantiation by MapDataSerializerHook.
MapReplicationStateHolder(MapReplicationOperation) - Constructor for class com.hazelcast.map.impl.operation.MapReplicationStateHolder
 
MapReplicationUpdate - Class in com.hazelcast.map.impl.wan
WAN replication object for map update operations.
MapReplicationUpdate() - Constructor for class com.hazelcast.map.impl.wan.MapReplicationUpdate
 
MapReplicationUpdate(String, SplitBrainMergePolicy, EntryView<Data, Data>) - Constructor for class com.hazelcast.map.impl.wan.MapReplicationUpdate
 
MapService - Class in com.hazelcast.map.impl
Defines map service behavior.
MapService() - Constructor for class com.hazelcast.map.impl.MapService
 
mapService - Variable in class com.hazelcast.map.impl.operation.MapOperation
 
MapServiceConstructor - Class in com.hazelcast.map.impl
Helper which is used to create a MapService object.
mapServiceContext - Variable in class com.hazelcast.map.impl.event.AbstractFilteringStrategy
 
mapServiceContext - Variable in class com.hazelcast.map.impl.event.MapEventPublisherImpl
 
mapServiceContext - Variable in class com.hazelcast.map.impl.MapContainer
 
mapServiceContext - Variable in class com.hazelcast.map.impl.MapService
 
MapServiceContext - Interface in com.hazelcast.map.impl
Context which is needed by a map service.
mapServiceContext - Variable in class com.hazelcast.map.impl.nearcache.MapNearCacheManager
 
mapServiceContext - Variable in class com.hazelcast.map.impl.operation.MapOperation
 
mapServiceContext - Variable in class com.hazelcast.map.impl.query.PartitionScanRunner
 
mapServiceContext - Variable in class com.hazelcast.map.impl.query.QueryRunner
 
mapServiceContext - Variable in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
 
MapServiceContextEventListenerSupport - Interface in com.hazelcast.map.impl
Helper event listener methods for MapServiceContext.
MapServiceContextInterceptorSupport - Interface in com.hazelcast.map.impl
Helper interceptor methods for MapServiceContext.
MapServiceFactory - Interface in com.hazelcast.map.impl
Factory which is used to create a MapService object and also aware of its MapServiceContext.
MapSetCodec - Class in com.hazelcast.client.impl.protocol.codec
Puts an entry into this map with a given ttl (time to live) value.Entry will expire and get evicted after the ttl If ttl is 0, then the entry lives forever.
MapSetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapSetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapSetMessageTask
 
MapSetReadCursorMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.ContinuousQueryMessageType#CONTINUOUSQUERY_SETREADCURSOR
MapSetReadCursorMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapSetReadCursorMessageTask
 
MapSetTtlCodec - Class in com.hazelcast.client.impl.protocol.codec
Updates TTL (time to live) value of the entry specified by key with a new TTL value.
MapSetTtlCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapSetTtlCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapSetTtlMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapSetTtlMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapSetTtlMessageTask
 
MapSetWithMaxIdleCodec - Class in com.hazelcast.client.impl.protocol.codec
Puts an entry into this map with a given ttl (time to live) value and maxIdle.
MapSetWithMaxIdleCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapSetWithMaxIdleCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapSetWithMaxIdleMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapSetWithMaxIdleMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapSetWithMaxIdleMessageTask
 
MapSizeCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the number of key-value mappings in this map.
MapSizeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapSizeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapSizeMessageTask
 
MapSizeOperation - Class in com.hazelcast.map.impl.operation
 
MapSizeOperation() - Constructor for class com.hazelcast.map.impl.operation.MapSizeOperation
 
MapSizeOperation(String) - Constructor for class com.hazelcast.map.impl.operation.MapSizeOperation
 
MapSplitBrainProtectionAwareService - Class in com.hazelcast.map.impl
Split brain protection service will ask map service about whether map has defined split brain protection or not.
MapSplitBrainProtectionAwareService(MapServiceContext) - Constructor for class com.hazelcast.map.impl.MapSplitBrainProtectionAwareService
 
MapStore<K,V> - Interface in com.hazelcast.map
Hazelcast distributed map implementation is an in-memory data store, but it can be backed by any type of data store such as RDBMS, OODBMS, NOSQL, or simply a file-based data store.
MapStoreAdapter<K,V> - Class in com.hazelcast.map
Adapter for MapStore.
MapStoreAdapter() - Constructor for class com.hazelcast.map.MapStoreAdapter
 
mapStoreConfig - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
configuration of backing map store or null for none
MapStoreConfig - Class in com.hazelcast.config
Contains the configuration for a Map Store.
MapStoreConfig() - Constructor for class com.hazelcast.config.MapStoreConfig
 
MapStoreConfig(MapStoreConfig) - Constructor for class com.hazelcast.config.MapStoreConfig
 
MapStoreConfig.InitialLoadMode - Enum in com.hazelcast.config
Initial load module
MapStoreConfigHolder - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
Client protocol adapter for MapStoreConfig
MapStoreConfigHolder() - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
MapStoreConfigHolder(boolean, boolean, int, int, String, Data, String, Data, Map<String, String>, String) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
MapStoreConfigHolderCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
MapStoreConfigReadOnly - Class in com.hazelcast.internal.config
Contains the configuration for a Map Store (read-only).
MapStoreConfigReadOnly(MapStoreConfig) - Constructor for class com.hazelcast.internal.config.MapStoreConfigReadOnly
 
mapStoreContext - Variable in class com.hazelcast.map.impl.MapContainer
 
MapStoreContext - Interface in com.hazelcast.map.impl.mapstore
A context which provides/initializes map store specific functionality.
MapStoreContextFactory - Class in com.hazelcast.map.impl.mapstore
A factory which creates MapStoreContext objects according to MapStoreConfig.
MapStoreFactory<K,V> - Interface in com.hazelcast.map
Factory for MapLoader or MapStore instances, specifiable in MapStoreConfig.
MapStoreManager - Interface in com.hazelcast.map.impl.mapstore
Central interface to manage map store.
MapStoreManagers - Class in com.hazelcast.map.impl.mapstore
Static factory class for various map store managers.
MapStoreWrapper - Class in com.hazelcast.map.impl
 
MapStoreWrapper(String, Object) - Constructor for class com.hazelcast.map.impl.MapStoreWrapper
 
MapSubmitToKeyCodec - Class in com.hazelcast.client.impl.protocol.codec
Applies the user defined EntryProcessor to the entry mapped by the key.
MapSubmitToKeyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapSubmitToKeyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapSubmitToKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapSubmitToKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapSubmitToKeyMessageTask
 
MapSubscriberRegistry - Class in com.hazelcast.map.impl.querycache.subscriber
Used to register and hold SubscriberRegistry per IMap.
MapSubscriberRegistry(QueryCacheContext) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.MapSubscriberRegistry
 
MapTransactionLogRecord - Class in com.hazelcast.map.impl.tx
Represents an operation on the map in the transaction log.
MapTransactionLogRecord() - Constructor for class com.hazelcast.map.impl.tx.MapTransactionLogRecord
 
MapTransactionLogRecord(String, Data, int, Operation, UUID, UUID) - Constructor for class com.hazelcast.map.impl.tx.MapTransactionLogRecord
 
MapTryLockCodec - Class in com.hazelcast.client.impl.protocol.codec
Tries to acquire the lock for the specified key for the specified lease time.After lease time, the lock will be released.If the lock is not available, then the current thread becomes disabled for thread scheduling purposes and lies dormant until one of two things happens the lock is acquired by the current thread, or the specified waiting time elapses.
MapTryLockCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapTryLockCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapTryLockMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapTryLockMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapTryLockMessageTask
 
MapTryPutCodec - Class in com.hazelcast.client.impl.protocol.codec
Tries to put the given key and value into this map within a specified timeout value.
MapTryPutCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapTryPutCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapTryPutMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapTryPutMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapTryPutMessageTask
 
MapTryRemoveCodec - Class in com.hazelcast.client.impl.protocol.codec
Tries to remove the entry with the given key from this map within the specified timeout value.
MapTryRemoveCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapTryRemoveCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapTryRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapTryRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapTryRemoveMessageTask
 
MapTxnOperation - Interface in com.hazelcast.map.impl.tx
Transactional operation interface for IMap
MapUnlockCodec - Class in com.hazelcast.client.impl.protocol.codec
Releases the lock for the specified key.
MapUnlockCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapUnlockCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapUnlockMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapUnlockMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapUnlockMessageTask
 
MapUtil - Class in com.hazelcast.internal.util
Utility class for Maps
MapValueCollection - Class in com.hazelcast.map.impl
 
MapValueCollection(Collection<Data>) - Constructor for class com.hazelcast.map.impl.MapValueCollection
 
MapValueCollection() - Constructor for class com.hazelcast.map.impl.MapValueCollection
 
MapValuesCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns a collection clone of the values contained in this map.
MapValuesCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapValuesCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapValuesMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapValuesMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapValuesMessageTask
 
MapValuesWithPagingPredicateCodec - Class in com.hazelcast.client.impl.protocol.codec
Queries the map based on the specified predicate and returns the values of matching entries.
MapValuesWithPagingPredicateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapValuesWithPagingPredicateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapValuesWithPagingPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapValuesWithPagingPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPagingPredicateMessageTask
 
MapValuesWithPredicateCodec - Class in com.hazelcast.client.impl.protocol.codec
Queries the map based on the specified predicate and returns the values of matching entries.Specified predicate runs on all members in parallel.
MapValuesWithPredicateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapValuesWithPredicateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MapValuesWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
 
MapValuesWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPredicateMessageTask
 
mark(int) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
markExpirable(long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
This method marks current replica as expirable and also starts expiration task if necessary.
markMigrated(VectorClock) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterImpl
Marks this CRDT as migrated.
markMigrated() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterImpl
Unconditionally marks this CRDT as migrated.
markPartitionAsIndexed(int, InternalIndex[]) - Static method in class com.hazelcast.query.impl.Indexes
Marks the given partition as indexed by the given indexes.
markPartitionAsIndexed(int) - Method in class com.hazelcast.query.impl.IndexImpl
 
markPartitionAsIndexed(int) - Method in interface com.hazelcast.query.impl.InternalIndex
Marks the given partition as indexed by this index.
markPartitionAsUnindexed(int, InternalIndex[]) - Static method in class com.hazelcast.query.impl.Indexes
Marks the given partition as unindexed by the given indexes.
markPartitionAsUnindexed(int) - Method in class com.hazelcast.query.impl.IndexImpl
 
markPartitionAsUnindexed(int) - Method in interface com.hazelcast.query.impl.InternalIndex
Marks the given partition as unindexed by this index.
markRecordStoreExpirable(long, long) - Method in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
markSupported() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
markUnassigned(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray12byteKeyImpl
 
markUnassigned(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
marshall(Object) - Method in class com.hazelcast.replicatedmap.impl.record.DataReplicatedRecordStore
 
marshall(Object) - Method in class com.hazelcast.replicatedmap.impl.record.ObjectReplicatedRecordStorage
 
marshall(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
mask - Variable in class com.hazelcast.security.permission.InstancePermission
 
MASK_FOR_SENSITIVE_DATA - Static variable in class com.hazelcast.config.ConfigXmlGenerator
 
MASTER_CLAIM - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
MASTER_RESPONSE - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
masterAddress - Variable in class com.hazelcast.internal.cluster.impl.operations.MasterResponseOp
 
MasterResponseOp - Class in com.hazelcast.internal.cluster.impl.operations
Operation sent by any node to set the master address on the receiver
MasterResponseOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.MasterResponseOp
 
MasterResponseOp(Address) - Constructor for class com.hazelcast.internal.cluster.impl.operations.MasterResponseOp
 
MASTERSHIP_CLAIM_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The timeout which defines when master candidate gives up waiting for response to its mastership claim.
match(String[], String[], int) - Method in class com.hazelcast.internal.util.AddressUtil.AddressMatcher
 
match(AddressUtil.AddressMatcher) - Method in class com.hazelcast.internal.util.AddressUtil.AddressMatcher
 
match(String) - Method in class com.hazelcast.internal.util.AddressUtil.AddressMatcher
 
match(String, QueryContext.IndexMatchHint) - Method in class com.hazelcast.query.impl.AttributeIndexRegistry
Matches an index for the given attribute and match hint.
matchAnyDomain(String, Collection<String>) - Static method in class com.hazelcast.internal.util.AddressUtil
 
matchAnyInterface(String, Collection<String>) - Static method in class com.hazelcast.internal.util.AddressUtil
 
matchDomain(String, String) - Static method in class com.hazelcast.internal.util.AddressUtil
 
matches(Iterable<String>, String) - Method in interface com.hazelcast.config.ConfigPatternMatcher
Returns the best match for an item name out of a list of configuration patterns.
matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.MatchingPointConfigPatternMatcher
 
matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.RegexConfigPatternMatcher
 
matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
 
matches(String, String) - Method in class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
This method is public to be accessible by InstancePermission.
matchIndex() - Method in class com.hazelcast.cp.internal.raft.impl.state.FollowerState
Returns the match index for follower.
matchIndex(long) - Method in class com.hazelcast.cp.internal.raft.impl.state.FollowerState
Sets the match index for follower.
matchIndex(String, QueryContext.IndexMatchHint) - Method in class com.hazelcast.query.impl.GlobalQueryContextWithStats
 
matchIndex(String, QueryContext.IndexMatchHint) - Method in class com.hazelcast.query.impl.Indexes
Matches an index for the given pattern and match hint.
matchIndex(String, QueryContext.IndexMatchHint) - Method in class com.hazelcast.query.impl.PartitionQueryContextWithStats
 
matchIndex(QueryContext, QueryContext.IndexMatchHint) - Method in class com.hazelcast.query.impl.predicates.AbstractIndexAwarePredicate
 
matchIndex(String, QueryContext.IndexMatchHint) - Method in class com.hazelcast.query.impl.QueryContext
Matches an index for the given pattern and match hint.
matchIndices() - Method in class com.hazelcast.cp.internal.raft.impl.state.LeaderState
Returns an array of match indices for all followers.
MatchingPointConfigPatternMatcher - Class in com.hazelcast.config.matcher
This ConfigPatternMatcher supports a simplified wildcard matching.
MatchingPointConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.MatchingPointConfigPatternMatcher
 
matchInterface(String, String) - Static method in class com.hazelcast.internal.util.AddressUtil
 
MAX - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
MAX_ADD_CACHE_CONFIG_RETRIES - Static variable in interface com.hazelcast.cache.impl.ICacheService
Maximum retries for adding cache config cluster-wide on stable cluster
MAX_ATTRIBUTES - Static variable in class com.hazelcast.query.impl.IndexUtils
Maximum number of attributes allowed in the index.
MAX_BACKOFF - Static variable in class com.hazelcast.topic.impl.reliable.ReliableTopicProxy
 
MAX_BACKUP_COUNT - Static variable in class com.hazelcast.config.CacheSimpleConfig
The maximum number of backups.
MAX_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
The maximum number of backups
MAX_BACKUP_COUNT - Static variable in interface com.hazelcast.spi.partition.IPartition
The maximum number of backups.
MAX_BATCH_SIZE - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferProxy
The maximum number of items that can be retrieved in 1 go using the RingbufferProxy.readManyAsync(long, int, int, IFunction) method.
MAX_BY - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
MAX_CAPACITY - Static variable in class com.hazelcast.internal.util.collection.IntHashSet
Maximum supported capacity
MAX_CAPACITY - Static variable in class com.hazelcast.internal.util.collection.LongHashSet
Maximum supported capacity
MAX_CONCURRENT_INVOCATIONS - Static variable in class com.hazelcast.client.properties.ClientProperty
The maximum number of concurrent invocations allowed.
MAX_DEVIATION_PERCENTAGE - Static variable in class com.hazelcast.internal.diagnostics.MemberHeartbeatPlugin
The maximum allowed deviation.
MAX_DEVIATION_PERCENTAGE - Static variable in class com.hazelcast.internal.diagnostics.OperationHeartbeatPlugin
The maximum allowed deviation.
MAX_GROUP_SIZE - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
The maximum number of CP members that can form a CP group.
MAX_INT_CAPACITY - Static variable in class com.hazelcast.internal.util.hashslot.impl.CapacityUtil
Maximum length of a Java array that is a power of two.
MAX_JOIN_MERGE_TARGET_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
MAX_JOIN_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
MAX_LONG_CAPACITY - Static variable in class com.hazelcast.internal.util.hashslot.impl.CapacityUtil
Maximum length of an off-heap array that is a power of two.
MAX_MESSAGE_SIZE_EXCEEDED - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
MAX_NO_HEARTBEAT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The timeout which defines when a cluster member is removed because it has not sent any heartbeats.
MAX_REPLICA_COUNT - Static variable in interface com.hazelcast.internal.partition.InternalPartition
 
MAX_RESULT_LIMIT_FACTOR - Static variable in class com.hazelcast.map.impl.query.QueryResultSizeLimiter
Adds a security margin to the configured result size limit to prevent false positives.
MAX_RESULT_LIMIT_FACTOR_FOR_PRECHECK - Static variable in class com.hazelcast.map.impl.query.QueryResultSizeLimiter
Adds a security margin to the configured result size limit to prevent false positives in pre-check.
MAX_ROLLED_FILE_COUNT - Static variable in class com.hazelcast.internal.diagnostics.Diagnostics
The DiagnosticsLogFile uses a rolling file approach to prevent eating too much disk space.
MAX_ROLLED_FILE_SIZE_MB - Static variable in class com.hazelcast.internal.diagnostics.Diagnostics
The DiagnosticsLogFile uses a rolling file approach to prevent eating too much disk space.
MAX_TOLERATED_MISS_COUNT - Static variable in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingTask
 
MAX_WAIT_SECONDS_BEFORE_JOIN - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
MaxAggregator<I,R extends Comparable> - Class in com.hazelcast.aggregation.impl
 
MaxAggregator() - Constructor for class com.hazelcast.aggregation.impl.MaxAggregator
 
MaxAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.MaxAggregator
 
maxBy(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
maxBy(Comparator<? super T>) - Static method in interface com.hazelcast.internal.util.function.BinaryOperatorEx
MaxByAggregator<I> - Class in com.hazelcast.aggregation.impl
 
MaxByAggregator() - Constructor for class com.hazelcast.aggregation.impl.MaxByAggregator
 
MaxByAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.MaxByAggregator
 
maxCount - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferReadManyCodec.RequestParameters
the maximum number of items to read.
maxIdle - Variable in class com.hazelcast.client.impl.protocol.codec.MapGetEntryViewCodec.ResponseParameters
TODO DOC
maxIdle - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentWithMaxIdleCodec.RequestParameters
The duration of maximum idle for this entry.
maxIdle - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutTransientWithMaxIdleCodec.RequestParameters
The duration of maximum idle for this entry.
maxIdle - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutWithMaxIdleCodec.RequestParameters
The duration of maximum idle for this entry.
maxIdle - Variable in class com.hazelcast.client.impl.protocol.codec.MapSetWithMaxIdleCodec.RequestParameters
The duration of maximum idle for this entry.
maxIdle - Variable in class com.hazelcast.map.impl.record.AbstractRecord
 
maxIdle - Variable in class com.hazelcast.map.impl.record.RecordInfo
 
maxIdleMillis - Variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
maxIdleSeconds - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
maximum number of seconds for each entry to stay idle in the map
MAXIMUM_PREFETCH_COUNT - Static variable in class com.hazelcast.config.FlakeIdGeneratorConfig
Maximum value for prefetch count.
maximumPoolSize - Variable in class com.hazelcast.internal.management.dto.ManagedExecutorDTO
 
MaxMessageSizeExceeded - Exception in com.hazelcast.client.impl.protocol.exception
Thrown when client message size exceeds Integer.MAX_VALUE
MaxMessageSizeExceeded() - Constructor for exception com.hazelcast.client.impl.protocol.exception.MaxMessageSizeExceeded
 
MaxMessageSizeExceeded(String) - Constructor for exception com.hazelcast.client.impl.protocol.exception.MaxMessageSizeExceeded
 
maxPoolSize() - Method in class com.hazelcast.internal.jmx.ManagedExecutorServiceMBean
 
maxSize - Variable in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalReadCodec.RequestParameters
the maximum number of items to read.
maxSize - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddListConfigCodec.RequestParameters
maximum size of the list
maxSize - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddQueueConfigCodec.RequestParameters
maximum number of items in the queue
maxSize - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddSetConfigCodec.RequestParameters
maximum size of the set
maxSize - Variable in class com.hazelcast.client.impl.protocol.codec.MapEventJournalReadCodec.RequestParameters
the maximum number of items to read.
maxSize - Variable in class com.hazelcast.client.impl.protocol.codec.QueueDrainToMaxSizeCodec.RequestParameters
The maximum number of elements to transfer
maxSize - Variable in class com.hazelcast.internal.journal.EventJournalReadOperation
 
MaxSizeConfig - Class in com.hazelcast.config
Configuration for map's capacity.
MaxSizeConfig() - Constructor for class com.hazelcast.config.MaxSizeConfig
 
MaxSizeConfig(int, MaxSizeConfig.MaxSizePolicy) - Constructor for class com.hazelcast.config.MaxSizeConfig
 
MaxSizeConfig(MaxSizeConfig) - Constructor for class com.hazelcast.config.MaxSizeConfig
 
MaxSizeConfig.MaxSizePolicy - Enum in com.hazelcast.config
Maximum Size Policy
maxSizeConfigMaxSizePolicy - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
maximum size policy.
MaxSizeConfigReadOnly - Class in com.hazelcast.internal.config
Contains the configuration for a size of Map.
MaxSizeConfigReadOnly(MaxSizeConfig) - Constructor for class com.hazelcast.internal.config.MaxSizeConfigReadOnly
 
maxSizeConfigSize - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
maximum size of map
maxSizePolicy - Variable in class com.hazelcast.config.EvictionConfig
 
maybeDoInitialLoad() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
maybeDoInitialLoad() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Resets the map loader state if necessary and triggers initial key and value loading if it has not been done before.
mayInterruptIfRunning - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromAddressCodec.RequestParameters
A boolean flag to indicate whether the task should be interrupted.
mayInterruptIfRunning - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromPartitionCodec.RequestParameters
A boolean flag to indicate whether the task should be interrupted.
MC_MAX_VISIBLE_SLOW_OPERATION_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
MCMutualAuthConfig - Class in com.hazelcast.config
Management Center mutual authentication configuration.
MCMutualAuthConfig() - Constructor for class com.hazelcast.config.MCMutualAuthConfig
 
MD5Util - Class in com.hazelcast.internal.util
Utility class for hashing with MD5
megaBytes() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in mega-bytes.
MEM - Static variable in class com.hazelcast.internal.memory.GlobalMemoryAccessorRegistry
A GlobalMemoryAccessor that allows both aligned and unaligned native memory access.
mem() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
mem - Variable in class com.hazelcast.internal.util.sort.MemArrayQuickSorter
 
MEM_AVAILABLE - Static variable in class com.hazelcast.internal.memory.GlobalMemoryAccessorRegistry
If this constant is true, then GlobalMemoryAccessorRegistry.MEM refers to a usable MemoryAccessor instance.
MEM_COPY_THRESHOLD - Static variable in interface com.hazelcast.internal.memory.GlobalMemoryAccessor
Maximum size of a block of memory to copy in a single low-level memory-copying operation.
MemArrayQuickSorter - Class in com.hazelcast.internal.util.sort
Base class for QuickSorter implementations on a memory block accessed by a MemoryAccessor.
MemArrayQuickSorter(MemoryAccessor, long) - Constructor for class com.hazelcast.internal.util.sort.MemArrayQuickSorter
 
Member - Interface in com.hazelcast.cluster
Cluster member interface.
member - Variable in class com.hazelcast.cluster.MembershipEvent
 
MEMBER - Static variable in class com.hazelcast.instance.EndpointQualifier
 
MEMBER - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
MEMBER_ADDED - Static variable in class com.hazelcast.cluster.MembershipEvent
This event type is fired when a new member joins the cluster.
MEMBER_ATTR_CHANGED - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
MEMBER_ATTRIBUTE_CHANGED - Static variable in class com.hazelcast.cluster.MembershipEvent
This event type is fired if a member attribute has been changed or removed.
MEMBER_BIN - Static variable in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
MEMBER_CALLABLE_TASK - Static variable in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
 
MEMBER_INFO - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
MEMBER_INFO_UPDATE - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
MEMBER_LEFT - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
MEMBER_LIST_PUBLISH_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The interval at which the master sends the member lists are sent to other non-master members
MEMBER_REMOVED - Static variable in class com.hazelcast.cluster.MembershipEvent
This event type is fired if a member left the cluster or was decided to be unresponsive by other members for a extended time.
MEMBER_VERSION - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
memberAdded(MembershipEvent) - Method in class com.hazelcast.client.util.AbstractLoadBalancer
 
memberAdded(MembershipEvent) - Method in class com.hazelcast.cluster.MembershipAdapter
 
memberAdded(MembershipEvent) - Method in interface com.hazelcast.cluster.MembershipListener
Invoked when a new member is added to the cluster.
memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.cp.internal.RaftService
 
memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.internal.crdt.CRDTReplicationMigrationService
 
memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
memberAdded(MembershipEvent) - Method in class com.hazelcast.internal.management.ManagementCenterService.MemberListenerImpl
 
memberAdded(Member) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
memberAdded(Member) - Method in interface com.hazelcast.internal.partition.InternalPartitionService
Called when a member is added to the cluster.
memberAdded(MembershipServiceEvent) - Method in interface com.hazelcast.internal.services.MembershipAwareService
Invoked when a new member is added to the cluster.
memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
memberAdded(MembershipEvent) - Method in class com.hazelcast.splitbrainprotection.impl.AbstractPingAwareSplitBrainProtectionFunction
 
memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.splitbrainprotection.impl.SplitBrainProtectionServiceImpl
 
memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
memberAddresses - Variable in class com.hazelcast.internal.cluster.impl.JoinMessage
 
memberAddressOf(Address) - Method in interface com.hazelcast.client.impl.ClientEngine
Locates the cluster member that has the provided client address and returns its member address, to be used for intra-cluster communication.
memberAddressOf(Address) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
memberAddressOf(Address) - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
MemberAddressProvider - Interface in com.hazelcast.spi
IMPORTANT This interface is not intended to provide addresses of other cluster members with which the hazelcast instance will form a cluster.
MemberAddressProviderConfig - Class in com.hazelcast.config
Configuration for a custom MemberAddressProvider strategy.
MemberAddressProviderConfig() - Constructor for class com.hazelcast.config.MemberAddressProviderConfig
 
MemberAlreadyExistsException - Exception in com.hazelcast.cp.internal.raft.exception
A CPSubsystemException which is thrown when a member, which is requested to be added to a CP group, is already member of that group.
MemberAlreadyExistsException(RaftEndpoint) - Constructor for exception com.hazelcast.cp.internal.raft.exception.MemberAlreadyExistsException
 
memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
memberAttributeChanged(MemberAttributeEvent) - Method in class com.hazelcast.client.util.AbstractLoadBalancer
 
memberAttributeChanged(MemberAttributeEvent) - Method in class com.hazelcast.cluster.MembershipAdapter
 
memberAttributeChanged(MemberAttributeEvent) - Method in interface com.hazelcast.cluster.MembershipListener
Invoked when an attribute of a member was changed.
memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.cp.internal.RaftService
 
memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.internal.crdt.CRDTReplicationMigrationService
 
memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
memberAttributeChanged(MemberAttributeEvent) - Method in class com.hazelcast.internal.management.ManagementCenterService.MemberListenerImpl
 
memberAttributeChanged(MemberAttributeServiceEvent) - Method in interface com.hazelcast.internal.services.MembershipAwareService
Invoked when a member attribute is changed.
memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
memberAttributeChanged(MemberAttributeEvent) - Method in class com.hazelcast.splitbrainprotection.impl.AbstractPingAwareSplitBrainProtectionFunction
 
memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.splitbrainprotection.impl.SplitBrainProtectionServiceImpl
 
memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
MemberAttributeChangedOp - Class in com.hazelcast.internal.cluster.impl.operations
 
MemberAttributeChangedOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.MemberAttributeChangedOp
 
MemberAttributeChangedOp(MemberAttributeOperationType, String, String) - Constructor for class com.hazelcast.internal.cluster.impl.operations.MemberAttributeChangedOp
 
MemberAttributeConfig - Class in com.hazelcast.config
Contains configuration for attribute of member.
MemberAttributeConfig() - Constructor for class com.hazelcast.config.MemberAttributeConfig
 
MemberAttributeConfig(MemberAttributeConfig) - Constructor for class com.hazelcast.config.MemberAttributeConfig
 
MemberAttributeConfigReadOnly - Class in com.hazelcast.internal.config
Contains configuration for attribute of member (Read-Only).
MemberAttributeConfigReadOnly(MemberAttributeConfig) - Constructor for class com.hazelcast.internal.config.MemberAttributeConfigReadOnly
 
MemberAttributeEvent - Class in com.hazelcast.cluster
Event for member attribute changes.
MemberAttributeEvent() - Constructor for class com.hazelcast.cluster.MemberAttributeEvent
 
MemberAttributeEvent(Cluster, Member, Set<Member>, MemberAttributeOperationType, String, Object) - Constructor for class com.hazelcast.cluster.MemberAttributeEvent
 
MemberAttributeFilter - Class in com.hazelcast.internal.usercodedeployment.impl.filter
 
MemberAttributeFilter(String) - Constructor for class com.hazelcast.internal.usercodedeployment.impl.filter.MemberAttributeFilter
 
MemberAttributeOperationType - Enum in com.hazelcast.cluster
Used to identify the type of member attribute change, either PUT or REMOVED.
MemberAttributeServiceEvent - Class in com.hazelcast.internal.services
This service event is fired to inform services about a change in a member's attributes collection
MemberAttributeServiceEvent() - Constructor for class com.hazelcast.internal.services.MemberAttributeServiceEvent
 
MemberAttributeServiceEvent(Cluster, MemberImpl, Set<Member>, MemberAttributeOperationType, String, Object) - Constructor for class com.hazelcast.internal.services.MemberAttributeServiceEvent
 
MemberCallableTaskOperation - Class in com.hazelcast.executor.impl.operations
 
MemberCallableTaskOperation() - Constructor for class com.hazelcast.executor.impl.operations.MemberCallableTaskOperation
 
MemberCallableTaskOperation(String, UUID, Data) - Constructor for class com.hazelcast.executor.impl.operations.MemberCallableTaskOperation
 
MemberChannelInitializer - Class in com.hazelcast.internal.nio.tcp
 
MemberCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
MemberConfigRequest - Class in com.hazelcast.internal.management.request
Request for fetching member XML configuration.
MemberConfigRequest() - Constructor for class com.hazelcast.internal.management.request.MemberConfigRequest
 
memberCount() - Method in class com.hazelcast.cp.internal.CPGroupInfo
 
memberCount() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftGroupMembers
Returns the number of members in this group.
memberCount() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns number of members in the last applied group members
MemberDoesNotExistException - Exception in com.hazelcast.cp.internal.raft.exception
A CPSubsystemException which is thrown when a member, which is requested to be removed from a CP group, is not a member of that group or is already removed from that group.
MemberDoesNotExistException(RaftEndpoint) - Constructor for exception com.hazelcast.cp.internal.raft.exception.MemberDoesNotExistException
 
MemberGroup - Interface in com.hazelcast.partition.membergroup
 
MemberGroupConfig - Class in com.hazelcast.config
Contains the configuration for a single member group.
MemberGroupConfig() - Constructor for class com.hazelcast.config.MemberGroupConfig
 
MemberGroupFactory - Interface in com.hazelcast.partition.membergroup
Defines how members will be grouped (e.g.
MemberGroupFactoryFactory - Class in com.hazelcast.partition.membergroup
 
MemberHazelcastInstanceInfoPlugin - Class in com.hazelcast.internal.diagnostics
Prints all kinds of Hazelcast member specific info.
MemberHazelcastInstanceInfoPlugin(NodeEngineImpl) - Constructor for class com.hazelcast.internal.diagnostics.MemberHazelcastInstanceInfoPlugin
 
MemberHeartbeatPlugin - Class in com.hazelcast.internal.diagnostics
A diagnostics plugin that checks the quality of member/member heartbeats.
MemberHeartbeatPlugin(NodeEngineImpl) - Constructor for class com.hazelcast.internal.diagnostics.MemberHeartbeatPlugin
 
MemberImpl - Class in com.hazelcast.client.impl
Client side specific Member implementation.
MemberImpl() - Constructor for class com.hazelcast.client.impl.MemberImpl
 
MemberImpl(Address, MemberVersion) - Constructor for class com.hazelcast.client.impl.MemberImpl
 
MemberImpl(Address, MemberVersion, UUID) - Constructor for class com.hazelcast.client.impl.MemberImpl
 
MemberImpl(Address, UUID, Map<String, String>, boolean) - Constructor for class com.hazelcast.client.impl.MemberImpl
 
MemberImpl(Address, MemberVersion, UUID, Map<String, String>, boolean) - Constructor for class com.hazelcast.client.impl.MemberImpl
 
MemberImpl(AbstractMember) - Constructor for class com.hazelcast.client.impl.MemberImpl
 
MemberImpl - Class in com.hazelcast.cluster.impl
 
MemberImpl() - Constructor for class com.hazelcast.cluster.impl.MemberImpl
 
MemberImpl(Address, MemberVersion, boolean) - Constructor for class com.hazelcast.cluster.impl.MemberImpl
 
MemberImpl(Address, MemberVersion, boolean, UUID) - Constructor for class com.hazelcast.cluster.impl.MemberImpl
 
MemberImpl(MemberImpl) - Constructor for class com.hazelcast.cluster.impl.MemberImpl
 
MemberImpl.Builder - Class in com.hazelcast.cluster.impl
 
memberImpls() - Method in class com.hazelcast.cp.internal.CPGroupInfo
 
MemberInfo - Class in com.hazelcast.internal.cluster
 
MemberInfo() - Constructor for class com.hazelcast.internal.cluster.MemberInfo
 
MemberInfo(Address, UUID, Map<String, String>, MemberVersion) - Constructor for class com.hazelcast.internal.cluster.MemberInfo
 
MemberInfo(Address, UUID, Map<String, String>, boolean, MemberVersion, Map<EndpointQualifier, Address>) - Constructor for class com.hazelcast.internal.cluster.MemberInfo
 
MemberInfo(Address, UUID, Map<String, String>, boolean, MemberVersion, int, Map<EndpointQualifier, Address>) - Constructor for class com.hazelcast.internal.cluster.MemberInfo
 
MemberInfo(MemberImpl) - Constructor for class com.hazelcast.internal.cluster.MemberInfo
 
MemberLeftException - Exception in com.hazelcast.core
A ExecutionException thrown when a member left during an invocation or execution.
MemberLeftException() - Constructor for exception com.hazelcast.core.MemberLeftException
 
MemberLeftException(String) - Constructor for exception com.hazelcast.core.MemberLeftException
 
MemberLeftException(Member) - Constructor for exception com.hazelcast.core.MemberLeftException
 
MemberLeftException(Throwable) - Constructor for exception com.hazelcast.core.MemberLeftException
 
MemberListenerImpl() - Constructor for class com.hazelcast.internal.management.ManagementCenterService.MemberListenerImpl
 
memberListJoinVersion(int) - Method in class com.hazelcast.cluster.impl.MemberImpl.Builder
 
MemberMapInvalidationMetaDataFetcher - Class in com.hazelcast.map.impl.nearcache.invalidation
InvalidationMetaDataFetcher for member side usage
MemberMapInvalidationMetaDataFetcher(ClusterService, OperationService, ILogger) - Constructor for class com.hazelcast.map.impl.nearcache.invalidation.MemberMapInvalidationMetaDataFetcher
 
MemberMinimalPartitionService - Class in com.hazelcast.map.impl.nearcache
Member side implementation of MinimalPartitionService
MemberMinimalPartitionService(IPartitionService) - Constructor for class com.hazelcast.map.impl.nearcache.MemberMinimalPartitionService
 
MemberPartitionState - Interface in com.hazelcast.monitor
Partition related statistics to be used by MemberState implementations.
MemberPartitionStateImpl - Class in com.hazelcast.monitor.impl
This class holds partition related statistics.
MemberPartitionStateImpl() - Constructor for class com.hazelcast.monitor.impl.MemberPartitionStateImpl
 
MemberProtocolEncoder - Class in com.hazelcast.internal.nio.tcp
 
MemberProtocolEncoder(OutboundHandler[]) - Constructor for class com.hazelcast.internal.nio.tcp.MemberProtocolEncoder
Decodes first 3 incoming bytes, validates against supportedProtocol and, when matching, replaces itself in the inbound pipeline with the next InboundHandler.
MemberProviderFilterParser - Class in com.hazelcast.internal.usercodedeployment.impl.filter
 
memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
memberRemoved(MembershipEvent) - Method in class com.hazelcast.client.util.AbstractLoadBalancer
 
memberRemoved(MembershipEvent) - Method in class com.hazelcast.cluster.MembershipAdapter
 
memberRemoved(MembershipEvent) - Method in interface com.hazelcast.cluster.MembershipListener
Invoked when an existing member leaves the cluster.
memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.cp.internal.RaftService
 
memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.internal.crdt.CRDTReplicationMigrationService
 
memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
memberRemoved(MembershipEvent) - Method in class com.hazelcast.internal.management.ManagementCenterService.MemberListenerImpl
 
memberRemoved(Member) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
memberRemoved(Member) - Method in interface com.hazelcast.internal.partition.InternalPartitionService
Called when a member is removed from the cluster.
memberRemoved(MembershipServiceEvent) - Method in interface com.hazelcast.internal.services.MembershipAwareService
Invoked when an existing member leaves the cluster.
memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
memberRemoved(MembershipEvent) - Method in class com.hazelcast.splitbrainprotection.impl.AbstractPingAwareSplitBrainProtectionFunction
 
memberRemoved(MembershipEvent) - Method in class com.hazelcast.splitbrainprotection.impl.ProbabilisticSplitBrainProtectionFunction
 
memberRemoved(MembershipEvent) - Method in class com.hazelcast.splitbrainprotection.impl.RecentlyActiveSplitBrainProtectionFunction
 
memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.splitbrainprotection.impl.SplitBrainProtectionServiceImpl
 
memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
members - Variable in class com.hazelcast.cluster.MembershipEvent
 
members() - Method in interface com.hazelcast.cp.CPGroup
Returns current members of the CP group
members() - Method in class com.hazelcast.cp.internal.CPGroupInfo
 
members() - Method in class com.hazelcast.cp.internal.CPGroupSummary
 
members() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftGroupMembers
Return all members in this group.
members() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns all members in the last applied group members
MEMBERS_VIEW - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
MEMBERS_VIEW_METADATA - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
MemberSelectingCollection<M extends Member> - Class in com.hazelcast.internal.cluster.impl
An immutable collection that applies all the MemberSelector instances to its internal Member collection.
MemberSelectingCollection(Collection<M>, MemberSelector) - Constructor for class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
 
MemberSelector - Interface in com.hazelcast.cluster
Implementations of this interface select members that are capable of executing a special kind of task.
The MemberSelector.select(Member) method is called for every available member in the cluster and it is up to the implementation to decide if the member is going to be used or not.
MemberSelectors - Class in com.hazelcast.cluster.memberselector
A utility class to get MemberSelector instances.
MEMBERSHIP_CHANGE_REPLICATE_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
MEMBERSHIP_CHANGE_SCHEDULE - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
MembershipAdapter - Class in com.hazelcast.cluster
Adapter for MembershipListener.
MembershipAdapter() - Constructor for class com.hazelcast.cluster.MembershipAdapter
 
MembershipAwareService - Interface in com.hazelcast.internal.services
An interface that can be implemented by a SPI service that needs to be notified members joining and leaving the cluster.
MembershipChangeMode - Enum in com.hazelcast.cp.internal.raft
Defines type of a membership change.
MembershipChangeSchedule - Class in com.hazelcast.cp.internal
When there is a membership change in CP Subsystem, all decided membership changes of Raft groups are maintained here.
MembershipChangeSchedule.CPGroupMembershipChange - Class in com.hazelcast.cp.internal
Contains a membership change that will be performed on a CP group
MembershipChangeTask - Class in com.hazelcast.cp.internal.raft.impl.task
MembershipChangeTask is executed to add/remove a member to the Raft group.
MembershipChangeTask(RaftNodeImpl, InternalCompletableFuture, RaftEndpoint, MembershipChangeMode) - Constructor for class com.hazelcast.cp.internal.raft.impl.task.MembershipChangeTask
 
MembershipChangeTask(RaftNodeImpl, InternalCompletableFuture, RaftEndpoint, MembershipChangeMode, Long) - Constructor for class com.hazelcast.cp.internal.raft.impl.task.MembershipChangeTask
 
MembershipEvent - Class in com.hazelcast.cluster
Membership event fired when a new member is added to the cluster and/or when a member leaves the cluster or when there is a member attribute change via Member.setAttribute(String, String) and similar methods.
MembershipEvent(Cluster, Member, int, Set<Member>) - Constructor for class com.hazelcast.cluster.MembershipEvent
 
MembershipListener - Interface in com.hazelcast.cluster
Cluster membership listener.
MembershipManager - Class in com.hazelcast.internal.cluster.impl
MembershipManager maintains member list and version, manages member update, suspicion and removal mechanisms.
MembershipServiceEvent - Class in com.hazelcast.internal.services
Membership event fired when a new member is added to the cluster and/or when a member leaves the cluster.
MembershipServiceEvent(MembershipEvent) - Constructor for class com.hazelcast.internal.services.MembershipServiceEvent
 
membersLogIndex() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns log index of the last applied group members
MemberSocketInterceptor - Interface in com.hazelcast.nio
Member Socket Interceptor can be registered via see SocketInterceptorConfig Warning: a MemberSocketInterceptor provides access to the socket and will bypass any TLS encryption.
MemberState - Interface in com.hazelcast.monitor
Local statistics for a Hazelcast member.
MemberStateImpl - Class in com.hazelcast.monitor.impl
 
MemberStateImpl() - Constructor for class com.hazelcast.monitor.impl.MemberStateImpl
 
MembersUpdateOp - Class in com.hazelcast.internal.cluster.impl.operations
 
MembersUpdateOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.MembersUpdateOp
 
MembersUpdateOp(UUID, MembersView, long, PartitionRuntimeState, boolean) - Constructor for class com.hazelcast.internal.cluster.impl.operations.MembersUpdateOp
 
MembersView - Class in com.hazelcast.internal.cluster.impl
MembersView is a container object to carry member list and version together.
MembersView() - Constructor for class com.hazelcast.internal.cluster.impl.MembersView
 
MembersView(int, List<MemberInfo>) - Constructor for class com.hazelcast.internal.cluster.impl.MembersView
 
MembersViewMetadata - Class in com.hazelcast.internal.cluster.impl
 
MembersViewMetadata() - Constructor for class com.hazelcast.internal.cluster.impl.MembersViewMetadata
 
MembersViewMetadata(Address, UUID, Address, int) - Constructor for class com.hazelcast.internal.cluster.impl.MembersViewMetadata
 
memberVersion - Variable in class com.hazelcast.internal.cluster.impl.JoinMessage
this is populated with the codebase version of the node trying to join the cluster (ie Node.getVersion()).
MemberVersion - Class in com.hazelcast.version
Determines the Hazelcast codebase version in terms of major.minor.patch version.
MemberVersion() - Constructor for class com.hazelcast.version.MemberVersion
 
MemberVersion(int, int, int) - Constructor for class com.hazelcast.version.MemberVersion
 
MemberVersion(String) - Constructor for class com.hazelcast.version.MemberVersion
 
MemberViewUnifiedEndpointManager - Class in com.hazelcast.internal.nio.tcp
 
MEMCACHE - Static variable in class com.hazelcast.instance.EndpointQualifier
 
MEMCACHE - Static variable in class com.hazelcast.internal.nio.Protocols
Protocol that is used by Memcached
MEMCACHE_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
MEMCACHE_ENTRY - Static variable in class com.hazelcast.internal.ascii.TextProtocolsDataSerializerHook
 
MemcacheCommandProcessor<T> - Class in com.hazelcast.internal.ascii.memcache
 
MemcacheCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.memcache.MemcacheCommandProcessor
 
MemcacheEntry - Class in com.hazelcast.internal.ascii.memcache
 
MemcacheEntry(String, byte[], int) - Constructor for class com.hazelcast.internal.ascii.memcache.MemcacheEntry
 
MemcacheEntry() - Constructor for class com.hazelcast.internal.ascii.memcache.MemcacheEntry
 
MemcacheProtocolConfig - Class in com.hazelcast.config
This class allows to enable MEMCACHE text protocol support in Hazelcast.
MemcacheProtocolConfig() - Constructor for class com.hazelcast.config.MemcacheProtocolConfig
 
MemcacheTextDecoder - Class in com.hazelcast.internal.nio.ascii
 
MemcacheTextDecoder(TcpIpConnection, TextEncoder, boolean) - Constructor for class com.hazelcast.internal.nio.ascii.MemcacheTextDecoder
 
MemcacheUtils - Class in com.hazelcast.internal.ascii.memcache
 
Memoizer<K,V> - Class in com.hazelcast.internal.util
Thread safe cache for memoizing the calculation for a specific key.
Memoizer(ConstructorFunction<K, V>) - Constructor for class com.hazelcast.internal.util.Memoizer
Constructs the memoizer.
MemoryAccessor - Interface in com.hazelcast.internal.memory
Abstraction over an address space of readable and writable bytes.
MemoryAllocator - Interface in com.hazelcast.internal.memory
Manages the usage of an address space by allocating and freeing blocks of addresses.
MemoryInfoAccessor - Interface in com.hazelcast.internal.util
Used for providing runtime memory information of Java virtual machine.
MemoryManager - Interface in com.hazelcast.internal.memory
Contract to allocate and access memory in an abstract address space, which is not necessarily the underlying CPU's native address space.
MemoryManagerBean - Class in com.hazelcast.internal.memory.impl
Simple implementation of MemoryManager which aggregates the MemoryAllocator and MemoryAccessor supplied at construction time.
MemoryManagerBean(MemoryAllocator, MemoryAccessor) - Constructor for class com.hazelcast.internal.memory.impl.MemoryManagerBean
 
MemorySize - Class in com.hazelcast.memory
MemorySize represents a memory size with given value and MemoryUnit.
MemorySize(long) - Constructor for class com.hazelcast.memory.MemorySize
 
MemorySize(long, MemoryUnit) - Constructor for class com.hazelcast.memory.MemorySize
 
MemoryStats - Interface in com.hazelcast.internal.memory
Memory statistics for the JVM which current HazelcastInstance belongs to.
MemoryStatsSupport - Class in com.hazelcast.internal.memory
This class provides heap usage statistics
MemoryUnit - Enum in com.hazelcast.memory
MemoryUnit represents memory size at a given unit of granularity and provides utility methods to convert across units.
merge(SplitBrainMergeTypes.CacheMergeTypes, SplitBrainMergePolicy<Data, SplitBrainMergeTypes.CacheMergeTypes>, CallerProvenance) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
MERGE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
merge(SplitBrainMergeTypes.CacheMergeTypes, SplitBrainMergePolicy<Data, SplitBrainMergeTypes.CacheMergeTypes>, CallerProvenance) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
merge(SplitBrainMergeTypes.CardinalityEstimatorMergeTypes, SplitBrainMergePolicy<HyperLogLog, SplitBrainMergeTypes.CardinalityEstimatorMergeTypes>, SerializationService) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
MERGE - Static variable in class com.hazelcast.cardinality.impl.CardinalityEstimatorDataSerializerHook
 
merge(HyperLogLog) - Method in interface com.hazelcast.cardinality.impl.hyperloglog.HyperLogLog
Merge the two HyperLogLog structures in one.
merge(HyperLogLogEncoder) - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.DenseHyperLogLogEncoder
 
merge(HyperLogLogEncoder) - Method in interface com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogEncoder
Merge the two HyperLogLog structures in one.
merge(HyperLogLog) - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogImpl
 
merge(HyperLogLogEncoder) - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.SparseHyperLogLogEncoder
 
merge(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
merge(VectorClock) - Method in class com.hazelcast.cluster.impl.VectorClock
Merges the provided vector clock into this one by taking the maximum of the logical timestamps for each replica.
MERGE - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
merge(Address) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
merge(T) - Method in interface com.hazelcast.internal.crdt.CRDT
Merges the state of a different replica into this CRDT.
merge(String, T) - Method in interface com.hazelcast.internal.crdt.CRDTReplicationAwareService
Performs a merge of the local name CRDT with the provided state.
merge(PNCounterImpl) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterImpl
 
merge(String, PNCounterImpl) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterService
 
merge(JsonObject) - Method in class com.hazelcast.internal.json.JsonObject
Copies all members of the specified object into this object.
MERGE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
merge(SplitBrainMergeTypes.MapMergeTypes, SplitBrainMergePolicy<Data, SplitBrainMergeTypes.MapMergeTypes>) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
merge(SplitBrainMergeTypes.MapMergeTypes, SplitBrainMergePolicy<Data, SplitBrainMergeTypes.MapMergeTypes>, CallerProvenance) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
merge(SplitBrainMergeTypes.MapMergeTypes, SplitBrainMergePolicy<Data, SplitBrainMergeTypes.MapMergeTypes>) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
merge(SplitBrainMergeTypes.MapMergeTypes, SplitBrainMergePolicy<Data, SplitBrainMergeTypes.MapMergeTypes>, CallerProvenance) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
merge(MultiMapMergeContainer, SplitBrainMergePolicy<Collection<Object>, SplitBrainMergeTypes.MultiMapMergeTypes>) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
Merges the given MultiMapMergeContainer via the given SplitBrainMergePolicy.
MERGE - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
merge(SplitBrainMergeTypes.ReplicatedMapMergeTypes, SplitBrainMergePolicy<Object, SplitBrainMergeTypes.ReplicatedMapMergeTypes>) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
merge(SplitBrainMergeTypes.ReplicatedMapMergeTypes, SplitBrainMergePolicy<Object, SplitBrainMergeTypes.ReplicatedMapMergeTypes>) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
merge(SplitBrainMergeTypes.ScheduledExecutorMergeTypes, SplitBrainMergePolicy<ScheduledTaskDescriptor, SplitBrainMergeTypes.ScheduledExecutorMergeTypes>) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
MERGE - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
merge(T, T) - Method in class com.hazelcast.spi.merge.DiscardMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.ExpirationTimeMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.HigherHitsMergePolicy
 
merge(SplitBrainMergeTypes.CardinalityEstimatorMergeTypes, SplitBrainMergeTypes.CardinalityEstimatorMergeTypes) - Method in class com.hazelcast.spi.merge.HyperLogLogMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.LatestAccessMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.LatestUpdateMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.PassThroughMergePolicy
 
merge(T, T) - Method in class com.hazelcast.spi.merge.PutIfAbsentMergePolicy
 
merge(T, T) - Method in interface com.hazelcast.spi.merge.SplitBrainMergePolicy
Selects the value of either the merging or the existing MergingValue which should be merged.
MERGE_BACKUP - Static variable in class com.hazelcast.cardinality.impl.CardinalityEstimatorDataSerializerHook
 
MERGE_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
MERGE_BACKUP - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
MERGE_BACKUP_OPERATION - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
MERGE_BACKUP_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
 
MERGE_CLUSTERS - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
MERGE_CONTAINER - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
MERGE_FACTORY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
MERGE_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MERGE_FACTORY - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
MERGE_FIRST_RUN_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The delay until the first run of the SplitBrainHandler
MERGE_NEXT_RUN_DELAY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The interval between invocations of the SplitBrainHandler
MERGE_OPERATION - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
MERGE_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
 
MERGE_POLICY_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MergeBackupOperation - Class in com.hazelcast.cardinality.impl.operations
Contains a backup HyperLogLog for split-brain healing with a SplitBrainMergePolicy.
MergeBackupOperation() - Constructor for class com.hazelcast.cardinality.impl.operations.MergeBackupOperation
 
MergeBackupOperation(String, HyperLogLog) - Constructor for class com.hazelcast.cardinality.impl.operations.MergeBackupOperation
 
MergeBackupOperation - Class in com.hazelcast.multimap.impl.operations
Creates backups for merged MultiMapRecord after split-brain healing with a SplitBrainMergePolicy.
MergeBackupOperation() - Constructor for class com.hazelcast.multimap.impl.operations.MergeBackupOperation
 
MergeBackupOperation - Class in com.hazelcast.ringbuffer.impl.operations
Contains the entire ringbuffer as a result of split-brain healing with a SplitBrainMergePolicy.
MergeBackupOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.MergeBackupOperation
 
MergeBackupOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
MergeBackupOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.MergeBackupOperation
 
mergeBatchSize - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCardinalityEstimatorConfigCodec.RequestParameters
TODO DOC
mergeBatchSize - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddListConfigCodec.RequestParameters
TODO DOC
mergeBatchSize - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
TODO DOC
mergeBatchSize - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMultiMapConfigCodec.RequestParameters
TODO DOC
mergeBatchSize - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddQueueConfigCodec.RequestParameters
TODO DOC
mergeBatchSize - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReplicatedMapConfigCodec.RequestParameters
TODO DOC
mergeBatchSize - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddRingbufferConfigCodec.RequestParameters
TODO DOC
mergeBatchSize - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddScheduledExecutorConfigCodec.RequestParameters
TODO DOC
mergeBatchSize - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddSetConfigCodec.RequestParameters
TODO DOC
MergeClustersOp - Class in com.hazelcast.internal.cluster.impl.operations
 
MergeClustersOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.MergeClustersOp
 
MergeClustersOp(Address) - Constructor for class com.hazelcast.internal.cluster.impl.operations.MergeClustersOp
 
MergeOperation - Class in com.hazelcast.cardinality.impl.operations
Contains a mergeable HyperLogLog instance for split-brain healing with a SplitBrainMergePolicy.
MergeOperation() - Constructor for class com.hazelcast.cardinality.impl.operations.MergeOperation
 
MergeOperation(String, SplitBrainMergePolicy<HyperLogLog, SplitBrainMergeTypes.CardinalityEstimatorMergeTypes>, HyperLogLog) - Constructor for class com.hazelcast.cardinality.impl.operations.MergeOperation
 
MergeOperation - Class in com.hazelcast.map.impl.operation
Contains multiple merge entries for split-brain healing with a SplitBrainMergePolicy.
MergeOperation() - Constructor for class com.hazelcast.map.impl.operation.MergeOperation
 
MergeOperation(String, List<SplitBrainMergeTypes.MapMergeTypes>, SplitBrainMergePolicy<Data, SplitBrainMergeTypes.MapMergeTypes>, boolean) - Constructor for class com.hazelcast.map.impl.operation.MergeOperation
 
MergeOperation - Class in com.hazelcast.multimap.impl.operations
Merges multiple MultiMapMergeContainer for split-brain healing with a SplitBrainMergePolicy.
MergeOperation() - Constructor for class com.hazelcast.multimap.impl.operations.MergeOperation
 
MergeOperation(String, List<MultiMapMergeContainer>, SplitBrainMergePolicy<Collection<Object>, SplitBrainMergeTypes.MultiMapMergeTypes>) - Constructor for class com.hazelcast.multimap.impl.operations.MergeOperation
 
MergeOperation - Class in com.hazelcast.replicatedmap.impl.operation
Contains multiple merging entries for split-brain healing with a SplitBrainMergePolicy.
MergeOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.MergeOperation
 
MergeOperation - Class in com.hazelcast.ringbuffer.impl.operations
Contains an entire ringbuffer for split-brain healing with a SplitBrainMergePolicy.
MergeOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.MergeOperation
 
MergeOperation(ObjectNamespace, SplitBrainMergePolicy<RingbufferMergeData, SplitBrainMergeTypes.RingbufferMergeTypes>, Ringbuffer<Object>) - Constructor for class com.hazelcast.ringbuffer.impl.operations.MergeOperation
 
MergeOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
MergeOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.MergeOperation
 
MergeOperation(String, List<SplitBrainMergeTypes.ScheduledExecutorMergeTypes>, SplitBrainMergePolicy<ScheduledTaskDescriptor, SplitBrainMergeTypes.ScheduledExecutorMergeTypes>) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.MergeOperation
 
MergeOperationFactory - Class in com.hazelcast.map.impl.operation
Inserts the merging entries for all partitions of a member via locally invoked MergeOperation.
MergeOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.MergeOperationFactory
 
MergeOperationFactory(String, int[], List<SplitBrainMergeTypes.MapMergeTypes>[], SplitBrainMergePolicy<Data, SplitBrainMergeTypes.MapMergeTypes>) - Constructor for class com.hazelcast.map.impl.operation.MergeOperationFactory
 
MergeOperationFactory - Class in com.hazelcast.replicatedmap.impl.operation
Inserts the merging entries for all partitions of a member via locally invoked MergeOperation.
MergeOperationFactory() - Constructor for class com.hazelcast.replicatedmap.impl.operation.MergeOperationFactory
 
MergeOperationFactory(String, int[], List<SplitBrainMergeTypes.ReplicatedMapMergeTypes>[], SplitBrainMergePolicy<Object, SplitBrainMergeTypes.ReplicatedMapMergeTypes>) - Constructor for class com.hazelcast.replicatedmap.impl.operation.MergeOperationFactory
 
mergePolicy - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
name of a class implementing com.hazelcast.cache.CacheMergePolicy that handles merging of values for this cache while recovering from network partitioning
mergePolicy - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCardinalityEstimatorConfigCodec.RequestParameters
TODO DOC
mergePolicy - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddListConfigCodec.RequestParameters
TODO DOC
mergePolicy - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
class name of a class implementing com.hazelcast.map.merge.MapMergePolicy to merge entries while recovering from a split brain
mergePolicy - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMultiMapConfigCodec.RequestParameters
TODO DOC
mergePolicy - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddQueueConfigCodec.RequestParameters
TODO DOC
mergePolicy - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReplicatedMapConfigCodec.RequestParameters
class name of a class implementing com.hazelcast.replicatedmap.merge.ReplicatedMapMergePolicy to merge entries while recovering from a split brain
mergePolicy - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddRingbufferConfigCodec.RequestParameters
TODO DOC
mergePolicy - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddScheduledExecutorConfigCodec.RequestParameters
TODO DOC
mergePolicy - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddSetConfigCodec.RequestParameters
TODO DOC
mergePolicy - Variable in class com.hazelcast.map.impl.operation.MergeOperationFactory
 
mergePolicyConfig(String, int) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AbstractAddConfigMessageTask
 
mergePolicyConfig - Variable in class com.hazelcast.config.AbstractBasicConfig
 
MergePolicyConfig - Class in com.hazelcast.config
Configuration for SplitBrainMergePolicy.
MergePolicyConfig() - Constructor for class com.hazelcast.config.MergePolicyConfig
 
MergePolicyConfig(String, int) - Constructor for class com.hazelcast.config.MergePolicyConfig
 
MergePolicyConfig(MergePolicyConfig) - Constructor for class com.hazelcast.config.MergePolicyConfig
 
MergePolicyConfigCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
MergePolicyConfigReadOnly - Class in com.hazelcast.internal.config
 
MergePolicyConfigReadOnly(MergePolicyConfig) - Constructor for class com.hazelcast.internal.config.MergePolicyConfigReadOnly
 
mergePolicyProvider - Variable in class com.hazelcast.cache.impl.AbstractCacheService
 
mergePolicyProvider - Variable in class com.hazelcast.spi.impl.merge.AbstractMergeRunnable
 
MergePolicyValidator - Class in com.hazelcast.internal.config
Validates a merge policy instance.
Merger(NodeEngine, Operation) - Constructor for class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService.Merger
 
mergeRecordExpiration(Record, EntryView) - Method in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
mergeRecordExpiration(Record, SplitBrainMergeTypes.MapMergeTypes) - Method in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
mergeStore(Store, BiConsumer<Integer, MergingItem>) - Method in class com.hazelcast.spi.impl.merge.AbstractMergeRunnable
Used to merge with SplitBrainMergePolicy.
MergingCosts<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of memory costs for the merging process after a split-brain.
MergingCreationTime<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view a creation time for the merging process after a split-brain.
mergingEntries - Variable in class com.hazelcast.map.impl.operation.MergeOperationFactory
 
MergingEntry<K,V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a data structure key/value-pair for the merging process after a split-brain.
MergingExpirationTime<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of an expiration time for the merging process after a split-brain.
MergingHits<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view access hits for the merging process after a split-brain.
MergingLastAccessTime<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a last access time for the merging process after a split-brain.
MergingLastStoredTime<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a last stored time for the merging process after a split-brain.
MergingLastUpdateTime<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a last update time for the merging process after a split-brain.
MergingMaxIdle<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a MaxIdle for the merging process after a split-brain.
MergingTTL<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a TTL for the merging process after a split-brain.
mergingValue - Variable in class com.hazelcast.core.EntryEvent
 
MergingValue<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a data structure value for the merging process after a split-brain.
MergingValueFactory - Class in com.hazelcast.spi.impl.merge
Provides static factory methods to create MergingValue and MergingEntry instances.
MergingVersion<V> - Interface in com.hazelcast.spi.merge
Represents a read-only view of a version for the merging process after a split-brain.
MERKLE_TREE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MERKLE_TREE_NODE_ENTRIES - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MerkleTree - Interface in com.hazelcast.wan.impl.merkletree
Interface defining methods for Merkle tree implementations
merkleTreeConfig - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
- merkle tree configuration
MerkleTreeConfig - Class in com.hazelcast.config
Configuration for a merkle tree.
MerkleTreeConfig() - Constructor for class com.hazelcast.config.MerkleTreeConfig
 
MerkleTreeConfig(MerkleTreeConfig) - Constructor for class com.hazelcast.config.MerkleTreeConfig
MerkleTreeConfigCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
MerkleTreeConfigReadOnly - Class in com.hazelcast.internal.config
 
MerkleTreeConfigReadOnly(MerkleTreeConfig) - Constructor for class com.hazelcast.internal.config.MerkleTreeConfigReadOnly
 
MerkleTreeNodeEntries - Class in com.hazelcast.map.impl
The map entries that belong to a specific merkle tree node.
MerkleTreeNodeEntries() - Constructor for class com.hazelcast.map.impl.MerkleTreeNodeEntries
 
MerkleTreeNodeEntries(int, Set<EntryView<Data, Data>>) - Constructor for class com.hazelcast.map.impl.MerkleTreeNodeEntries
 
MerkleTreeUtil - Class in com.hazelcast.wan.impl.merkletree
Utility methods for Merkle tree implementation
message - Variable in class com.hazelcast.client.impl.protocol.codec.TopicPublishCodec.RequestParameters
The message to publish to all subscribers of this topic
message() - Method in interface com.hazelcast.internal.auditlog.AuditableEvent
 
message(String) - Method in interface com.hazelcast.internal.auditlog.EventBuilder
 
message(String) - Method in class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService.Builder
 
message() - Method in class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService.NoOpEvent
 
Message<E> - Class in com.hazelcast.topic
Message for ITopic.
Message(String, E, long, Member) - Constructor for class com.hazelcast.topic.Message
 
MessageListener<E> - Interface in com.hazelcast.topic
Message listener for ITopic.
messageObject - Variable in class com.hazelcast.topic.Message
 
MessageRunner<E> - Class in com.hazelcast.topic.impl.reliable
An ExecutionCallback that will try to read an item from the ringbuffer or blocks if no item is available.
MessageRunner(UUID, ReliableMessageListener<E>, Ringbuffer<ReliableTopicMessage>, String, int, SerializationService, Executor, ConcurrentMap<UUID, MessageRunner<E>>, ILogger) - Constructor for class com.hazelcast.topic.impl.reliable.MessageRunner
 
MessageTask - Interface in com.hazelcast.client.impl.protocol.task
Interface for all client message tasks to implement
MessageTaskFactory - Interface in com.hazelcast.client.impl.protocol
Message task factory interface
MessageTaskFactoryProvider - Interface in com.hazelcast.client.impl.protocol
Provider for client's Message task factories; Will be read from META-INF/services
Metadata - Class in com.hazelcast.query.impl
Keeps generic metadata for a key value pair.
Metadata() - Constructor for class com.hazelcast.query.impl.Metadata
 
METADATA_CP_GROUP_NAME - Static variable in interface com.hazelcast.cp.CPGroup
Name of the internal CP group that is used for maintaining CP groups and CP members
METADATA_RAFT_GROUP_SNAPSHOT - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
MetadataAwareValue(V) - Constructor for class com.hazelcast.map.EntryLoader.MetadataAwareValue
Creates a value without attaching an expiration time
MetadataAwareValue(V, long) - Constructor for class com.hazelcast.map.EntryLoader.MetadataAwareValue
Creates a value and attaches an expiration time to it.
MetaDataContainer - Class in com.hazelcast.internal.nearcache.impl.invalidation
Contains one partitions' invalidation metadata.
MetaDataContainer() - Constructor for class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataContainer
 
metaDataGenerator - Variable in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
 
MetaDataGenerator - Class in com.hazelcast.internal.nearcache.impl.invalidation
Responsible for partition-sequence and partition UUID generation.
MetaDataGenerator(int) - Constructor for class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataGenerator
 
MetadataHolder() - Constructor for class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationMetaDataFetcher.MetadataHolder
 
MetadataInitializer - Interface in com.hazelcast.map.impl
MetadataInitializer is used to process and generate metadata from keys and values saved in map store.
metadataPolicy - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
metadata policy configuration for the supported data types.
MetadataPolicy - Enum in com.hazelcast.config
Hazelcast may process objects of supported types ahead of time to create additional metadata about them.
MetadataRaftGroupInitInProgressException - Exception in com.hazelcast.cp.internal.exception
Thrown when all CP members have not committed their CP member list and initialization of the Metadata Raft group is not completed yet.
MetadataRaftGroupInitInProgressException() - Constructor for exception com.hazelcast.cp.internal.exception.MetadataRaftGroupInitInProgressException
 
MetadataRaftGroupManager - Class in com.hazelcast.cp.internal
Maintains CP Subsystem metadata, such as CP groups, active CP members, leaving and joining CP members, etc.
MetadataRaftGroupOp - Class in com.hazelcast.cp.internal.raftop.metadata
Base class for the RaftOp impls that are committed to the Metadata group.
MetadataRaftGroupOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.MetadataRaftGroupOp
 
MetadataRaftGroupSnapshot - Class in com.hazelcast.cp.internal
Snapshot of the Metadata Raft group state
MetadataRaftGroupSnapshot() - Constructor for class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
MetaDataResponse() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation.MetaDataResponse
 
MetaDataResponse() - Constructor for class com.hazelcast.map.impl.operation.MapGetInvalidationMetaDataOperation.MetaDataResponse
 
MethodGetter - Class in com.hazelcast.query.impl.getters
 
MethodGetter(Getter, Method, String, Class) - Constructor for class com.hazelcast.query.impl.getters.MethodGetter
 
MethodGetter(Getter, Method, String, Class, Class) - Constructor for class com.hazelcast.query.impl.getters.MethodGetter
 
MethodNotAvailable - Annotation Type in com.hazelcast.internal.adapter
Marks methods which are not available in a DataStructureAdapter implementation.
Metric - Class in com.hazelcast.internal.metrics.managementcenter
Represents a metric data point (key and value).
Metric - Interface in com.hazelcast.internal.metrics
A Metric is a 'quantitative measure' of something for example the number of operations pending, number of operations per second being executed etc.
MetricConsumer - Interface in com.hazelcast.internal.metrics.managementcenter
An interface that allows consuming keys and primitive values stored in Metric objects.
metricId() - Method in class com.hazelcast.internal.metrics.impl.MetricTaggerImpl
 
metricId() - Method in interface com.hazelcast.internal.metrics.MetricTagger
Returns the id for the metric.
metricName() - Method in class com.hazelcast.internal.metrics.impl.MetricTaggerImpl
 
metricName() - Method in interface com.hazelcast.internal.metrics.MetricTagger
Returns the name for the metric.
METRICS_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
METRICS_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
MetricsCollector - Interface in com.hazelcast.internal.metrics.collectors
With the MetricsCollector the metrics registered in the MetricsRegistry can be collected.
MetricsCompressor - Class in com.hazelcast.internal.metrics.managementcenter
Helper class for compressing metrics into a byte[] blob to be read by various consumers.
MetricsCompressor() - Constructor for class com.hazelcast.internal.metrics.managementcenter.MetricsCompressor
 
MetricsConfig - Class in com.hazelcast.config
Configuration options specific to metrics collection.
MetricsConfig() - Constructor for class com.hazelcast.config.MetricsConfig
 
MetricsConfig(MetricsConfig) - Constructor for class com.hazelcast.config.MetricsConfig
 
MetricsDataSerializerHook - Class in com.hazelcast.internal.metrics.managementcenter
 
MetricsDataSerializerHook() - Constructor for class com.hazelcast.internal.metrics.managementcenter.MetricsDataSerializerHook
 
MetricsExtractor - Interface in com.hazelcast.internal.metrics
An interface that extracts the metrics from the objects collected by the DynamicMetricsProvider implementations.
MetricsMBean - Class in com.hazelcast.internal.metrics.jmx
 
MetricsMBean() - Constructor for class com.hazelcast.internal.metrics.jmx.MetricsMBean
 
MetricsPlugin - Class in com.hazelcast.internal.diagnostics
A DiagnosticsPlugin that displays the content of the MetricsRegistry.
MetricsPlugin(NodeEngineImpl) - Constructor for class com.hazelcast.internal.diagnostics.MetricsPlugin
 
MetricsPlugin(ILogger, MetricsRegistry, HazelcastProperties) - Constructor for class com.hazelcast.internal.diagnostics.MetricsPlugin
 
MetricsPublisher - Interface in com.hazelcast.internal.metrics
Represents an object which publishes a set of metrics to some destination.
MetricsReadMetricsCodec - Class in com.hazelcast.client.impl.protocol.codec
Reads the recorded metrics starting with the smallest sequence number greater or equals to the sequence number set in fromSequence.
MetricsReadMetricsCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MetricsReadMetricsCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MetricsRegistry - Interface in com.hazelcast.internal.metrics
The MetricsRegistry is a registry of various Hazelcast/JVM internal information to help out with debugging, performance or stability issues.
metricsRegistry(MetricsRegistry) - Method in class com.hazelcast.internal.networking.nio.NioNetworking.Context
 
MetricsRegistryImpl - Class in com.hazelcast.internal.metrics.impl
The MetricsRegistry implementation.
MetricsRegistryImpl(ILogger, ProbeLevel) - Constructor for class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
Creates a MetricsRegistryImpl instance.
MetricsRegistryImpl(String, ILogger, ProbeLevel) - Constructor for class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
Creates a MetricsRegistryImpl instance.
MetricsResultSet - Class in com.hazelcast.internal.metrics.managementcenter
 
MetricsResultSet(long, List<Map.Entry<Long, byte[]>>) - Constructor for class com.hazelcast.internal.metrics.managementcenter.MetricsResultSet
 
MetricsService - Class in com.hazelcast.internal.metrics.impl
Service collecting the Metrics periodically and publishes them via MetricsPublishers.
MetricsService(NodeEngine) - Constructor for class com.hazelcast.internal.metrics.impl.MetricsService
 
MetricsService(NodeEngine, Supplier<MetricsRegistry>) - Constructor for class com.hazelcast.internal.metrics.impl.MetricsService
 
MetricsUtil - Class in com.hazelcast.internal.metrics
A utility to escape and parse metric key in tagged format:
MetricTagger - Interface in com.hazelcast.internal.metrics
Interface to be used for tagging a metric.
MetricTaggerImpl - Class in com.hazelcast.internal.metrics.impl
Immutable implementation of MetricTagger.
MetricTaggerSupplier - Interface in com.hazelcast.internal.metrics
Interface used to get a MetricTagger based on its namespace.
MetricTarget - Enum in com.hazelcast.internal.metrics
Enum representing the target platforms of the metrics collection.
MigratablePipeline - Interface in com.hazelcast.internal.networking.nio
A NioPipeline that supports migration between NioThread instances.
migrateTo(MemoryAllocator) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
Migrates the backing memory region to a new allocator, freeing the current region.
MIGRATION - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
MIGRATION_COMMIT - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
MIGRATION_EVENT - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
MIGRATION_EVENT_TOPIC - Static variable in interface com.hazelcast.internal.partition.InternalPartitionService
Static constant for dispatching and listening migration events
MIGRATION_INFO - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
MIGRATION_REQUEST - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
MIGRATION_RETRY_COUNT - Static variable in interface com.hazelcast.internal.partition.InternalPartitionService
Retry count for migration operations.
MIGRATION_RETRY_PAUSE - Static variable in interface com.hazelcast.internal.partition.InternalPartitionService
Retry pause for migration operations in milliseconds.
migrationAwareService - Variable in class com.hazelcast.map.impl.MapService
 
MigrationAwareService - Interface in com.hazelcast.spi.partition
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a MapService starts moving its data around because partitions are moving to a different machine.
MigrationCommitOperation - Class in com.hazelcast.internal.partition.operation
Sent by the master node to commit a migration on the migration destination.
MigrationCommitOperation() - Constructor for class com.hazelcast.internal.partition.operation.MigrationCommitOperation
 
MigrationCommitOperation(MigrationInfo, UUID) - Constructor for class com.hazelcast.internal.partition.operation.MigrationCommitOperation
 
MigrationCycleOperation - Interface in com.hazelcast.internal.partition
 
migrationData - Variable in class com.hazelcast.collection.impl.collection.operations.CollectionReplicationOperation
 
MigrationEndpoint - Enum in com.hazelcast.spi.partition
Denotes endpoint of a migration.
migrationFinished(MigrationState) - Method in interface com.hazelcast.partition.MigrationListener
Called when the migration process finishes.
MigrationInfo - Class in com.hazelcast.internal.partition
 
MigrationInfo() - Constructor for class com.hazelcast.internal.partition.MigrationInfo
 
MigrationInfo(int, PartitionReplica, PartitionReplica, int, int, int, int) - Constructor for class com.hazelcast.internal.partition.MigrationInfo
 
MigrationInfo.MigrationStatus - Enum in com.hazelcast.internal.partition
 
MigrationInterceptor - Interface in com.hazelcast.internal.partition.impl
Internal synchronous/blocking listener to intercept migration cycle on master member and migration participants.
MigrationInterceptor.MigrationParticipant - Enum in com.hazelcast.internal.partition.impl
 
MigrationInterceptor.NopMigrationInterceptor - Class in com.hazelcast.internal.partition.impl
 
MigrationListener - Interface in com.hazelcast.partition
MigrationListener provides the ability to listen to partition migration process and events.
MigrationManager - Class in com.hazelcast.internal.partition.impl
Maintains migration system state and manages migration operations performed within the cluster.
MigrationOperation - Class in com.hazelcast.internal.partition.operation
Migration operation used by Hazelcast version 3.9 It runs on the migration destination and applies the received fragments.
MigrationOperation() - Constructor for class com.hazelcast.internal.partition.operation.MigrationOperation
 
MigrationOperation(MigrationInfo, List<MigrationInfo>, int, ReplicaFragmentMigrationState, boolean, boolean) - Constructor for class com.hazelcast.internal.partition.operation.MigrationOperation
 
MigrationRequestOperation - Class in com.hazelcast.internal.partition.operation
Migration request operation used by Hazelcast version 3.9 Sent from the master node to the partition owner.
MigrationRequestOperation() - Constructor for class com.hazelcast.internal.partition.operation.MigrationRequestOperation
 
MigrationRequestOperation(MigrationInfo, List<MigrationInfo>, int, boolean) - Constructor for class com.hazelcast.internal.partition.operation.MigrationRequestOperation
 
migrationStarted(MigrationState) - Method in interface com.hazelcast.partition.MigrationListener
Called when the migration process starts.
MigrationState - Interface in com.hazelcast.partition
MigrationState shows statistical information about the migration, such as; migration start time, number of planned replica migrations, number of completed replica migrations, total elapsed migration time etc.
MigrationStateImpl - Class in com.hazelcast.internal.partition
Summary of the migration state.
MigrationStateImpl() - Constructor for class com.hazelcast.internal.partition.MigrationStateImpl
 
MigrationStateImpl(long, int, int, long) - Constructor for class com.hazelcast.internal.partition.MigrationStateImpl
 
MigrationStats - Class in com.hazelcast.internal.partition.impl
Collection of stats for partition migration tasks.
MigrationStats() - Constructor for class com.hazelcast.internal.partition.impl.MigrationStats
 
MILLI_SECONDS_IN_A_SECOND - Static variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
MIME_TEXT_PLAIN - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
 
MIN - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
MIN_BACKUP_COUNT - Static variable in class com.hazelcast.config.CacheSimpleConfig
The minimum number of backups.
MIN_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
The minimum number of backups
MIN_BY - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
MIN_CAPACITY - Static variable in class com.hazelcast.internal.util.hashslot.impl.CapacityUtil
Minimum capacity for a hash container.
MIN_GROUP_SIZE - Static variable in class com.hazelcast.config.cp.CPSubsystemConfig
The minimum number of CP members that can form a CP group.
MIN_INITIAL_MEMORY_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
Minimum initial memory size in megabytes
MIN_RECONCILIATION_INTERVAL_SECONDS - Static variable in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingTask
 
MinAggregator<I,R extends Comparable> - Class in com.hazelcast.aggregation.impl
 
MinAggregator() - Constructor for class com.hazelcast.aggregation.impl.MinAggregator
 
MinAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.MinAggregator
 
minBy(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
minBy(Comparator<? super T>) - Static method in interface com.hazelcast.internal.util.function.BinaryOperatorEx
MinByAggregator<I> - Class in com.hazelcast.aggregation.impl
 
MinByAggregator() - Constructor for class com.hazelcast.aggregation.impl.MinByAggregator
 
MinByAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.MinByAggregator
 
minCount - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferReadManyCodec.RequestParameters
the minimum number of items to read.
MINIMAL - Static variable in class com.hazelcast.internal.json.WriterConfig
Write JSON in its minimal form, without any additional whitespace.
MinimalPartitionService - Interface in com.hazelcast.internal.nearcache.impl.invalidation
Abstraction over member and client partition services to provide commonly useful methods.
MINIMUM_MAX_RESULT_LIMIT - Static variable in class com.hazelcast.map.impl.query.QueryResultSizeLimiter
Defines the minimum value for the result size limit to ensure a sufficient distribution of data in the partitions.
minimumClusterSize - Variable in class com.hazelcast.config.SplitBrainProtectionConfigBuilder
The minimum cluster size: expected number of live members in cluster not to be considered it split
minimumLevel() - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
 
minimumLevel() - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
Returns the minimum ProbeLevel this MetricsRegistry is recording.
minSize - Variable in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalReadCodec.RequestParameters
the minimum number of items to read.
minSize - Variable in class com.hazelcast.client.impl.protocol.codec.MapEventJournalReadCodec.RequestParameters
the minimum number of items to read.
minSize - Variable in class com.hazelcast.internal.journal.EventJournalReadOperation
 
MismatchingGroupMembersCommitIndexException - Exception in com.hazelcast.cp.internal.raft.exception
A CPSubsystemException which is thrown when a membership change is requested but expected members commitIndex doesn't match the actual members commitIndex in the Raft state.
MismatchingGroupMembersCommitIndexException(long, Collection<RaftEndpoint>) - Constructor for exception com.hazelcast.cp.internal.raft.exception.MismatchingGroupMembersCommitIndexException
 
MISSES - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
misses - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
MOBY_NAMING_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines whether Moby Names should be used for instance name generating when it is not provided by user.
mode - Variable in class com.hazelcast.internal.management.dto.ClientBwListDTO
 
mode() - Method in class com.hazelcast.map.impl.query.Target
 
modificationType - Variable in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
 
modifyOutputStream(JarOutputStream) - Method in class com.hazelcast.buildutils.HazelcastManifestTransformer
 
modPowerOfTwo(int, int) - Static method in class com.hazelcast.internal.util.QuickMath
Computes the remainder of the division of a by b.
modPowerOfTwo(long, int) - Static method in class com.hazelcast.internal.util.QuickMath
Computes the remainder of the division of a by b.
ModularJavaUtils - Class in com.hazelcast.internal.util
Helper class for simplify work with Java module system (Java 9+) in older Java versions.
MorphingPortableReader - Class in com.hazelcast.internal.serialization.impl
Enables reading from a portable byte stream if the portableVersion from the classDefinition is different than the portableVersion from the byte stream.
MorphingPortableReader(PortableSerializer, BufferObjectDataInput, ClassDefinition) - Constructor for class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
MPSCQueue<E> - Class in com.hazelcast.internal.util.concurrent
Multi producer single consumer queue.
MPSCQueue(Thread, IdleStrategy) - Constructor for class com.hazelcast.internal.util.concurrent.MPSCQueue
Creates a new MPSCQueue with the provided IdleStrategy and consumer thread.
MPSCQueue(IdleStrategy) - Constructor for class com.hazelcast.internal.util.concurrent.MPSCQueue
Creates a new MPSCQueue with the provided IdleStrategy.
MULTI_ATTRIBUTE - Static variable in class com.hazelcast.projection.impl.ProjectionDataSerializerHook
 
MULTI_MAP_MERGING_ENTRY - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
multiAttribute(String...) - Static method in class com.hazelcast.projection.Projections
Returns a projection that extracts the value of the given attributePaths.
MultiAttributeProjection<I> - Class in com.hazelcast.projection.impl
Projection that extracts the values of the given attributes and returns them in an Object[] array.
MultiAttributeProjection(String...) - Constructor for class com.hazelcast.projection.impl.MultiAttributeProjection
 
MulticastConfig - Class in com.hazelcast.config
Contains the configuration for the multicast discovery mechanism.
MulticastConfig() - Constructor for class com.hazelcast.config.MulticastConfig
 
MulticastDiscoveryReceiver - Class in com.hazelcast.spi.discovery.multicast.impl
 
MulticastDiscoveryReceiver(MulticastSocket, ILogger) - Constructor for class com.hazelcast.spi.discovery.multicast.impl.MulticastDiscoveryReceiver
 
MulticastDiscoverySender - Class in com.hazelcast.spi.discovery.multicast.impl
 
MulticastDiscoverySender(DiscoveryNode, MulticastSocket, ILogger, String, int) - Constructor for class com.hazelcast.spi.discovery.multicast.impl.MulticastDiscoverySender
 
MulticastDiscoveryStrategy - Class in com.hazelcast.spi.discovery.multicast
The multicast DiscoveryStrategy.
MulticastDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Constructor for class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
 
MulticastDiscoveryStrategyFactory - Class in com.hazelcast.spi.discovery.multicast
Factory class which returns MulticastDiscoveryStrategy to Discovery SPI
MulticastDiscoveryStrategyFactory() - Constructor for class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategyFactory
 
MulticastJoiner - Class in com.hazelcast.internal.cluster.impl
 
MulticastJoiner(Node) - Constructor for class com.hazelcast.internal.cluster.impl.MulticastJoiner
 
MulticastListener - Interface in com.hazelcast.internal.cluster.impl
 
MulticastMemberInfo - Class in com.hazelcast.spi.discovery.multicast.impl
 
MulticastMemberInfo(String, int) - Constructor for class com.hazelcast.spi.discovery.multicast.impl.MulticastMemberInfo
 
MulticastProperties - Class in com.hazelcast.spi.discovery.multicast
Defines the name and default value for the Multicast Discovery Strategy.
multicastService - Variable in class com.hazelcast.instance.impl.Node
 
MulticastService - Class in com.hazelcast.internal.cluster.impl
 
MultiExecutionCallback - Interface in com.hazelcast.core
MultiExecutionCallback provides notification for when an execution is completed on each member that a task is submitted to.
MultiMap<K,V> - Interface in com.hazelcast.multimap
A specialized map whose keys can be associated with multiple values.
MULTIMAP_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
MULTIMAP_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
MULTIMAP_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
MULTIMAP_EVENT_FILTER - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
MULTIMAP_OP_FACTORY - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
MULTIMAP_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
MULTIMAP_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
MULTIMAP_RECORD - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
MULTIMAP_REPLICATION_OPERATION - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
MULTIMAP_RESPONSE - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
MULTIMAP_TRANSACTION_LOG_RECORD - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
MultiMapAddEntryListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds an entry listener for this multimap.
MultiMapAddEntryListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapAddEntryListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapAddEntryListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapAddEntryListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_ADDENTRYLISTENER
MultiMapAddEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerMessageTask
 
MultiMapAddEntryListenerToKeyCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds the specified entry listener for the specified key.The listener will be notified for all add/remove/update/evict events for the specified key only.
MultiMapAddEntryListenerToKeyCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapAddEntryListenerToKeyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapAddEntryListenerToKeyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapAddEntryListenerToKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_ADDENTRYLISTENERTOKEY
MultiMapAddEntryListenerToKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerToKeyMessageTask
 
MultiMapClearCodec - Class in com.hazelcast.client.impl.protocol.codec
Clears the multimap.
MultiMapClearCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapClearCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapClearMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_CLEAR
MultiMapClearMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapClearMessageTask
 
MultiMapConfig - Class in com.hazelcast.config
Configuration for MultiMap.
MultiMapConfig() - Constructor for class com.hazelcast.config.MultiMapConfig
 
MultiMapConfig(String) - Constructor for class com.hazelcast.config.MultiMapConfig
 
MultiMapConfig(MultiMapConfig) - Constructor for class com.hazelcast.config.MultiMapConfig
 
MultiMapConfig.ValueCollectionType - Enum in com.hazelcast.config
Type of value collection
MultiMapConfigReadOnly - Class in com.hazelcast.internal.config
Contains the configuration for an MultiMap.
MultiMapConfigReadOnly(MultiMapConfig) - Constructor for class com.hazelcast.internal.config.MultiMapConfigReadOnly
 
MultiMapContainer - Class in com.hazelcast.multimap.impl
MultiMap container which holds a map of MultiMapValue.
MultiMapContainer(String, MultiMapService, int) - Constructor for class com.hazelcast.multimap.impl.MultiMapContainer
 
MultiMapContainsEntryCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns whether the multimap contains the given key-value pair.
MultiMapContainsEntryCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapContainsEntryCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapContainsEntryMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_CONTAINSENTRY
MultiMapContainsEntryMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsEntryMessageTask
 
MultiMapContainsKeyCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns whether the multimap contains an entry with the key.
MultiMapContainsKeyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapContainsKeyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapContainsKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_CONTAINSKEY
MultiMapContainsKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsKeyMessageTask
 
MultiMapContainsValueCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns whether the multimap contains an entry with the value.
MultiMapContainsValueCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapContainsValueCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapContainsValueMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_CONTAINSVALUE
MultiMapContainsValueMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsValueMessageTask
 
MultiMapDataSerializerHook - Class in com.hazelcast.multimap.impl
 
MultiMapDataSerializerHook() - Constructor for class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
MultiMapDeleteCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes all the entries with the given key.
MultiMapDeleteCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapDeleteCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapDeleteMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_DELETE
MultiMapDeleteMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapDeleteMessageTask
 
MultiMapEntrySetCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the set of key-value pairs in the multimap.The collection is NOT backed by the map, so changes to the map are NOT reflected in the collection, and vice-versa
MultiMapEntrySetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapEntrySetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapEntrySetMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_ENTRYSET
MultiMapEntrySetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
 
MultiMapEventFilter - Class in com.hazelcast.multimap.impl
 
MultiMapEventFilter() - Constructor for class com.hazelcast.multimap.impl.MultiMapEventFilter
 
MultiMapEventFilter(boolean, Data) - Constructor for class com.hazelcast.multimap.impl.MultiMapEventFilter
 
MultiMapEventsPublisher - Class in com.hazelcast.multimap.impl
Publishes multimap entry and map events through eventService
MultiMapEventsPublisher(NodeEngine) - Constructor for class com.hazelcast.multimap.impl.MultiMapEventsPublisher
 
MultiMapForceUnlockCodec - Class in com.hazelcast.client.impl.protocol.codec
Releases the lock for the specified key regardless of the lock owner.
MultiMapForceUnlockCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapForceUnlockCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapForceUnlockMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_FORCEUNLOCK
MultiMapForceUnlockMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
 
MultiMapGetCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the collection of values associated with the key.
MultiMapGetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapGetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_GET
MultiMapGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapGetMessageTask
 
MultiMapIsLockedCodec - Class in com.hazelcast.client.impl.protocol.codec
Checks the lock for the specified key.
MultiMapIsLockedCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapIsLockedCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapIsLockedMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_ISLOCKED
MultiMapIsLockedMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
 
MultiMapKeySetCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the set of keys in the multimap.The collection is NOT backed by the map, so changes to the map are NOT reflected in the collection, and vice-versa.
MultiMapKeySetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapKeySetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapKeySetMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_KEYSET
MultiMapKeySetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
 
MultiMapLockCodec - Class in com.hazelcast.client.impl.protocol.codec
Acquires the lock for the specified key for the specified lease time.
MultiMapLockCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapLockCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapLockMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID:
MultiMapLockMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
 
MultiMapMBean - Class in com.hazelcast.internal.jmx
Management bean for MultiMap
MultiMapMBean(MultiMap, ManagementService) - Constructor for class com.hazelcast.internal.jmx.MultiMapMBean
 
MultiMapMergeContainer - Class in com.hazelcast.multimap.impl
Container for the merge operation of a MultiMap.
MultiMapMergeContainer() - Constructor for class com.hazelcast.multimap.impl.MultiMapMergeContainer
 
MultiMapMergeContainer(Data, Collection<MultiMapRecord>, long, long, long, long) - Constructor for class com.hazelcast.multimap.impl.MultiMapMergeContainer
 
MultiMapMergingEntryImpl - Class in com.hazelcast.spi.impl.merge
MultiMapMergingEntryImpl() - Constructor for class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
MultiMapMergingEntryImpl(SerializationService) - Constructor for class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
MultiMapOperationFactory - Class in com.hazelcast.multimap.impl.operations
 
MultiMapOperationFactory() - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
 
MultiMapOperationFactory(String, MultiMapOperationFactory.OperationFactoryType) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
 
MultiMapOperationFactory(String, MultiMapOperationFactory.OperationFactoryType, Data, Data) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
 
MultiMapOperationFactory(String, MultiMapOperationFactory.OperationFactoryType, Data, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
 
MultiMapOperationFactory.OperationFactoryType - Enum in com.hazelcast.multimap.impl.operations
 
MultiMapPartitionContainer - Class in com.hazelcast.multimap.impl
 
MultiMapPermission - Class in com.hazelcast.security.permission
 
MultiMapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.MultiMapPermission
 
MultiMapProxySupport - Class in com.hazelcast.multimap.impl
 
MultiMapProxySupport(MultiMapConfig, MultiMapService, NodeEngine, String) - Constructor for class com.hazelcast.multimap.impl.MultiMapProxySupport
 
MultiMapPutCodec - Class in com.hazelcast.client.impl.protocol.codec
Stores a key-value pair in the multimap.
MultiMapPutCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapPutCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapPutMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_PUT
MultiMapPutMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapPutMessageTask
 
MultiMapRecord - Class in com.hazelcast.multimap.impl
 
MultiMapRecord() - Constructor for class com.hazelcast.multimap.impl.MultiMapRecord
 
MultiMapRecord(Object) - Constructor for class com.hazelcast.multimap.impl.MultiMapRecord
 
MultiMapRecord(long, Object) - Constructor for class com.hazelcast.multimap.impl.MultiMapRecord
 
MultiMapRemoveCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the given key value pair from the multimap.
MultiMapRemoveCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapRemoveCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapRemoveEntryCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes all the entries with the given key.
MultiMapRemoveEntryCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapRemoveEntryCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapRemoveEntryListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the specified entry listener.
MultiMapRemoveEntryListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapRemoveEntryListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapRemoveEntryListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_REMOVEENTRYLISTENER
MultiMapRemoveEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
 
MultiMapRemoveEntryMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_REMOVEENTRY
MultiMapRemoveEntryMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryMessageTask
 
MultiMapRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_REMOVE
MultiMapRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveMessageTask
 
MultiMapReplicationOperation - Class in com.hazelcast.multimap.impl.operations
 
MultiMapReplicationOperation() - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapReplicationOperation
 
MultiMapReplicationOperation(Map<String, Map<Data, MultiMapValue>>) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapReplicationOperation
 
MultiMapResponse - Class in com.hazelcast.multimap.impl.operations
 
MultiMapResponse() - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapResponse
 
MultiMapResponse(Collection, MultiMapConfig.ValueCollectionType) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapResponse
 
MultiMapService - Class in com.hazelcast.multimap.impl
 
MultiMapService(NodeEngine) - Constructor for class com.hazelcast.multimap.impl.MultiMapService
 
MultiMapSizeCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the number of key-value pairs in the multimap.
MultiMapSizeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapSizeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_SIZE
MultiMapSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
 
MultiMapTransactionLogRecord - Class in com.hazelcast.multimap.impl.txn
 
MultiMapTransactionLogRecord() - Constructor for class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
 
MultiMapTransactionLogRecord(int, Data, String, long, long) - Constructor for class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
 
MultiMapTryLockCodec - Class in com.hazelcast.client.impl.protocol.codec
Tries to acquire the lock for the specified key for the specified lease time.
MultiMapTryLockCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapTryLockCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapTryLockMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID:
MultiMapTryLockMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
 
MultiMapUnlockCodec - Class in com.hazelcast.client.impl.protocol.codec
Releases the lock for the specified key regardless of the lock owner.
MultiMapUnlockCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapUnlockCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapUnlockMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_UNLOCK
MultiMapUnlockMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
 
MultiMapValue - Class in com.hazelcast.multimap.impl
The MultiMapValue is the value in a multimap and it contains either a set or a list as collection.
MultiMapValue(Collection<MultiMapRecord>) - Constructor for class com.hazelcast.multimap.impl.MultiMapValue
 
MultiMapValueCountCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the number of values that match the given key in the multimap.
MultiMapValueCountCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapValueCountCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapValueCountMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_VALUECOUNT
MultiMapValueCountMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValueCountMessageTask
 
MultiMapValuesCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the collection of values in the multimap.The collection is NOT backed by the map, so changes to the map are NOT reflected in the collection, and vice-versa.
MultiMapValuesCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapValuesCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
MultiMapValuesMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.MultiMapMessageType#MULTIMAP_VALUES
MultiMapValuesMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
 
MULTIPLE_ENTRY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MULTIPLE_ENTRY_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MULTIPLE_ENTRY_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MULTIPLE_ENTRY_PREDICATE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MULTIPLE_ENTRY_PREDICATE_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
MultipleEntryBackupOperation - Class in com.hazelcast.map.impl.operation
 
MultipleEntryBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryBackupOperation
 
MultipleEntryBackupOperation(String, Set<Data>, EntryProcessor) - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryBackupOperation
 
MultipleEntryOperation - Class in com.hazelcast.map.impl.operation
 
MultipleEntryOperation() - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryOperation
 
MultipleEntryOperation(String, Set<Data>, EntryProcessor) - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryOperation
 
MultipleEntryOperationFactory - Class in com.hazelcast.map.impl.operation
 
MultipleEntryOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryOperationFactory
 
MultipleEntryOperationFactory(String, Set<Data>, EntryProcessor) - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryOperationFactory
 
MultipleEntryWithPredicateBackupOperation - Class in com.hazelcast.map.impl.operation
 
MultipleEntryWithPredicateBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryWithPredicateBackupOperation
 
MultipleEntryWithPredicateBackupOperation(String, Set<Data>, EntryProcessor, Predicate) - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryWithPredicateBackupOperation
 
MultipleEntryWithPredicateOperation - Class in com.hazelcast.map.impl.operation
 
MultipleEntryWithPredicateOperation() - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryWithPredicateOperation
 
MultipleEntryWithPredicateOperation(String, Set<Data>, EntryProcessor, Predicate) - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryWithPredicateOperation
 
MultiResult<T> - Class in com.hazelcast.query.impl.getters
Represents multiple results from a single attribute extraction.
MultiResult() - Constructor for class com.hazelcast.query.impl.getters.MultiResult
 
MultiResult(List<T>) - Constructor for class com.hazelcast.query.impl.getters.MultiResult
 
MultiResultSet - Interface in com.hazelcast.query.impl
TODO:
multiThreadingEnabled - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddTopicConfigCodec.RequestParameters
true to enable multi-threaded processing of incoming messages, otherwise a single thread will handle all topic messages
MurmurHash3_fmix(int) - Static method in class com.hazelcast.internal.util.HashUtil
 
MurmurHash3_fmix(long) - Static method in class com.hazelcast.internal.util.HashUtil
 
MurmurHash3_x64_64(byte[], int, int) - Static method in class com.hazelcast.internal.util.HashUtil
Returns the MurmurHash3_x86_32 hash of a block inside a byte array.
MurmurHash3_x64_64_direct(long, int, int) - Static method in class com.hazelcast.internal.util.HashUtil
 
MurmurHash3_x64_64_direct(MemoryAccessor, long, int, int) - Static method in class com.hazelcast.internal.util.HashUtil
Returns the MurmurHash3_x64_64 hash of a memory block accessed by the provided MemoryAccessor.
MurmurHash3_x86_32(byte[], int, int) - Static method in class com.hazelcast.internal.util.HashUtil
Returns the MurmurHash3_x86_32 hash of a block inside a byte array.
MurmurHash3_x86_32_direct(long, int, int) - Static method in class com.hazelcast.internal.util.HashUtil
 
MurmurHash3_x86_32_direct(MemoryAccessor, long, int, int) - Static method in class com.hazelcast.internal.util.HashUtil
Returns the MurmurHash3_x86_32 hash of a memory block accessed by the provided MemoryAccessor.
MutableInteger - Class in com.hazelcast.internal.util
Mutable integer which can be used for counting purposes.
MutableInteger() - Constructor for class com.hazelcast.internal.util.MutableInteger
 
MutableLong - Class in com.hazelcast.internal.util
Mutable long which can be used for counting purposes.
MutableLong() - Constructor for class com.hazelcast.internal.util.MutableLong
 
MutableOperation - Interface in com.hazelcast.cache.impl.operation
 
MutableYamlMapping - Interface in com.hazelcast.internal.yaml
Mutable interface of YamlMapping
MutableYamlNode - Interface in com.hazelcast.internal.yaml
Mutable interface for YamlNode instances.
MutableYamlScalar - Interface in com.hazelcast.internal.yaml
Mutable interface of YamlScalar
MutableYamlSequence - Interface in com.hazelcast.internal.yaml
Mutable interface of YamlSequence
MutatingCacheOperation - Class in com.hazelcast.cache.impl.operation
Base class for all mutable cache operations.
MutatingCacheOperation() - Constructor for class com.hazelcast.cache.impl.operation.MutatingCacheOperation
 
MutatingCacheOperation(String, Data, int) - Constructor for class com.hazelcast.cache.impl.operation.MutatingCacheOperation
 
MutatingOperation - Interface in com.hazelcast.spi.impl.operationservice
Marker interface for operations that change state/data.
MUTATION_DISALLOWED_EXCEPTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
MutationDisallowedException - Exception in com.hazelcast.crdt
Exception that indicates that the state found on this replica disallows mutation.
MutationDisallowedException(String) - Constructor for exception com.hazelcast.crdt.MutationDisallowedException
 
mutationTolerantIterator() - Method in interface com.hazelcast.map.impl.recordstore.Storage
Returned iterator from this method doesn't throw ConcurrentModificationException to fail fast.
mutationTolerantIterator() - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
mutex - Variable in class com.hazelcast.cache.impl.CachePartitionSegment
 
mutexFor(Object) - Method in class com.hazelcast.internal.util.ContextMutexFactory
 
MwCounter - Class in com.hazelcast.internal.util.counters
A Counter that is thread-safe; so can be incremented by multiple threads concurrently.
MXBeansDTO - Class in com.hazelcast.internal.management.dto
Holder class for serializable service beans.
MXBeansDTO() - Constructor for class com.hazelcast.internal.management.dto.MXBeansDTO
 
MXBeanUtil - Class in com.hazelcast.cache.impl
MXBean utility methods related to registration of the beans.

N

NA_MEMBER_LIST_JOIN_VERSION - Static variable in class com.hazelcast.cluster.impl.MemberImpl
Denotes that member list join version of a member is not known yet.
name - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
the full name of the cache, including the manager scope prefix
name - Variable in class com.hazelcast.cache.impl.event.AbstractICacheEvent
 
name - Variable in class com.hazelcast.cardinality.impl.operations.AbstractCardinalityEstimatorOperation
 
name - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongAddAndGetCodec.RequestParameters
Name of this IAtomicLong instance.
name - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongAlterCodec.RequestParameters
Name of this IAtomicLong instance.
name - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongApplyCodec.RequestParameters
Name of this IAtomicLong instance.
name - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongCompareAndSetCodec.RequestParameters
Name of this IAtomicLong instance.
name - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndAddCodec.RequestParameters
Name of this IAtomicLong instance.
name - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndSetCodec.RequestParameters
Name of this IAtomicLong instance.
name - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetCodec.RequestParameters
Name of this IAtomicLong instance.
name - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefApplyCodec.RequestParameters
The name of this IAtomicReference instance.
name - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefCompareAndSetCodec.RequestParameters
Name of this IAtomicReference instance.
name - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefContainsCodec.RequestParameters
Name of this IAtomicReference instance.
name - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefGetCodec.RequestParameters
Name of this IAtomicReference instance.
name - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefSetCodec.RequestParameters
Name of this IAtomicReference instance.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheAddEntryListenerCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheAddInvalidationListenerCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheAddNearCacheInvalidationListenerCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheAddPartitionLostListenerCodec.RequestParameters
Name of the cache
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheClearCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheContainsKeyCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheDestroyCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheEntryProcessorCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalReadCodec.RequestParameters
name of the cache
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalSubscribeCodec.RequestParameters
name of the cache
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAllCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAndRemoveCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAndReplaceCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetConfigCodec.RequestParameters
Name of the cache with prefix.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheIterateCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheIterateEntriesCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheListenerRegistrationCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheLoadAllCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheManagementConfigCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CachePutAllCodec.RequestParameters
name of the cache
name - Variable in class com.hazelcast.client.impl.protocol.codec.CachePutCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CachePutIfAbsentCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllKeysCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveEntryListenerCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveInvalidationListenerCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheRemovePartitionLostListenerCodec.RequestParameters
Name of the Cache
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheReplaceCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheSetExpiryPolicyCodec.RequestParameters
name of the cache
name - Variable in class com.hazelcast.client.impl.protocol.codec.CacheSizeCodec.RequestParameters
Name of the cache.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorAddCodec.RequestParameters
The name of CardinalityEstimator
name - Variable in class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorEstimateCodec.RequestParameters
The name of CardinalityEstimator
name - Variable in class com.hazelcast.client.impl.protocol.codec.ClientCreateProxyCodec.RequestParameters
The distributed object name for which the proxy is being created for.
name - Variable in class com.hazelcast.client.impl.protocol.codec.ClientDestroyProxyCodec.RequestParameters
The distributed object name for which the proxy is being destroyed for.
name - Variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchAwaitCodec.RequestParameters
Name of this CountDownLatch instance
name - Variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchCountDownCodec.RequestParameters
Name of the CountDownLatch instance
name - Variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetCountCodec.RequestParameters
Name of the CountDownLatch instance
name - Variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetRoundCodec.RequestParameters
Name of the CountDownLatch instance
name - Variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchTrySetCountCodec.RequestParameters
Name of the CountDownLatch instance
name - Variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorDisposeResultCodec.RequestParameters
Name of the executor.
name - Variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorIsShutdownCodec.RequestParameters
Name of the executor.
name - Variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveAndDisposeResultCodec.RequestParameters
Name of the executor.
name - Variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveResultCodec.RequestParameters
Name of the executor.
name - Variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorShutdownCodec.RequestParameters
Name of the executor.
name - Variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorSubmitToPartitionCodec.RequestParameters
Name of the executor.
name - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
cache name
name - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCardinalityEstimatorConfigCodec.RequestParameters
name of the cardinality estimator configuration
name - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddDurableExecutorConfigCodec.RequestParameters
durable executor name
name - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddExecutorConfigCodec.RequestParameters
executor's name
name - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddFlakeIdGeneratorConfigCodec.RequestParameters
name of FlakeIdGenerator
name - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddListConfigCodec.RequestParameters
list's name
name - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
TODO DOC
name - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMultiMapConfigCodec.RequestParameters
multimap configuration name
name - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddPNCounterConfigCodec.RequestParameters
name of the CRDT PN counter configuration
name - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddQueueConfigCodec.RequestParameters
queue name
name - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReliableTopicConfigCodec.RequestParameters
name of reliable topic
name - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReplicatedMapConfigCodec.RequestParameters
name of the replicated map configuration
name - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddRingbufferConfigCodec.RequestParameters
ringbuffer configuration name
name - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddScheduledExecutorConfigCodec.RequestParameters
name of scheduled executor
name - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddSetConfigCodec.RequestParameters
set's name
name - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddTopicConfigCodec.RequestParameters
topic's name
name - Variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceIsShutdownCodec.RequestParameters
Name of the executor.
name - Variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceShutdownCodec.RequestParameters
Name of the executor.
name - Variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToAddressCodec.RequestParameters
Name of the executor.
name - Variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToPartitionCodec.RequestParameters
Name of the executor.
name - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockGetLockOwnershipCodec.RequestParameters
Name of this FencedLock instance
name - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockLockCodec.RequestParameters
Name of this FencedLock instance
name - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockTryLockCodec.RequestParameters
Name of this FencedLock instance
name - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockUnlockCodec.RequestParameters
Name of this FencedLock instance
name - Variable in class com.hazelcast.client.impl.protocol.codec.FlakeIdGeneratorNewIdBatchCodec.RequestParameters
TODO DOC
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListAddAllCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListAddAllWithIndexCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListAddCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListAddListenerCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListAddWithIndexCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListClearCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListCompareAndRemoveAllCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListCompareAndRetainAllCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListContainsAllCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListContainsCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListGetAllCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListGetCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListIndexOfCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListIsEmptyCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListIteratorCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListLastIndexOfCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListListIteratorCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListRemoveCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListRemoveListenerCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListRemoveWithIndexCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListSetCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListSizeCodec.RequestParameters
Name of List
name - Variable in class com.hazelcast.client.impl.protocol.codec.ListSubCodec.RequestParameters
Name of the List
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyWithPredicateCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerWithPredicateCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddIndexCodec.RequestParameters
Name of map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddInterceptorCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheEntryListenerCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheInvalidationListenerCodec.RequestParameters
name of the map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddPartitionLostListenerCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapAggregateCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapAggregateWithPredicateCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapClearCodec.RequestParameters
of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapClearNearCacheCodec.RequestParameters
TODO DOC
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapContainsKeyCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapContainsValueCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapDeleteCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPagingPredicateCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPredicateCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapEntrySetCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapEventJournalReadCodec.RequestParameters
name of the map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapEventJournalSubscribeCodec.RequestParameters
name of the map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapEvictAllCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapEvictCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnAllKeysCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeyCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeysCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteWithPredicateCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchEntriesCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchKeysCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchWithQueryCodec.RequestParameters
Name of the map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapFlushCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapForceUnlockCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapGetAllCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapGetCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapGetEntryViewCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapIsEmptyCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapIsLockedCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapKeySetCodec.RequestParameters
name of the map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPagingPredicateCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPredicateCodec.RequestParameters
name of map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapLoadAllCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapLoadGivenKeysCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapLockCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapProjectCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapProjectWithPredicateCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutAllCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentWithMaxIdleCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutTransientCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutTransientWithMaxIdleCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutWithMaxIdleCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveAllCodec.RequestParameters
map name.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveEntryListenerCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveIfSameCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveInterceptorCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemovePartitionLostListenerCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapReplaceCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapReplaceIfSameCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapSetCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapSetTtlCodec.RequestParameters
Name of the map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapSetWithMaxIdleCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapSizeCodec.RequestParameters
of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapSubmitToKeyCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapTryLockCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapTryPutCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapTryRemoveCodec.RequestParameters
Name of the map.
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapUnlockCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapValuesCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapValuesWithPagingPredicateCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MapValuesWithPredicateCodec.RequestParameters
name of map
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerToKeyCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapClearCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsEntryCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsKeyCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsValueCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapDeleteCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapEntrySetCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapForceUnlockCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapGetCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapIsLockedCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapKeySetCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapLockCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapPutCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryListenerCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapSizeCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapTryLockCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapUnlockCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapValueCountCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapValuesCodec.RequestParameters
Name of the MultiMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.PNCounterAddCodec.RequestParameters
the name of the PNCounter
name - Variable in class com.hazelcast.client.impl.protocol.codec.PNCounterGetCodec.RequestParameters
the name of the PNCounter
name - Variable in class com.hazelcast.client.impl.protocol.codec.PNCounterGetConfiguredReplicaCountCodec.RequestParameters
the name of the PNCounter
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueueAddAllCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueueAddListenerCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueueClearCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRemoveAllCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRetainAllCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueueContainsAllCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueueContainsCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueueDrainToCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueueDrainToMaxSizeCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueueIsEmptyCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueueIteratorCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueueOfferCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueuePeekCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueuePollCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueuePutCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueueRemainingCapacityCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueueRemoveCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueueRemoveListenerCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueueSizeCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.QueueTakeCodec.RequestParameters
Name of the Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerCodec.RequestParameters
Name of the ReplicatedMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyCodec.RequestParameters
Name of the Replicated Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyWithPredicateCodec.RequestParameters
Name of the Replicated Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerWithPredicateCodec.RequestParameters
Name of the Replicated Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddNearCacheEntryListenerCodec.RequestParameters
Name of the ReplicatedMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapClearCodec.RequestParameters
Name of the Replicated Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsKeyCodec.RequestParameters
Name of the ReplicatedMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsValueCodec.RequestParameters
Name of the ReplicatedMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapEntrySetCodec.RequestParameters
Name of the ReplicatedMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapGetCodec.RequestParameters
Name of the ReplicatedMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapIsEmptyCodec.RequestParameters
Name of the ReplicatedMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapKeySetCodec.RequestParameters
Name of the ReplicatedMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutAllCodec.RequestParameters
Name of the ReplicatedMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutCodec.RequestParameters
Name of the ReplicatedMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveCodec.RequestParameters
Name of the ReplicatedMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveEntryListenerCodec.RequestParameters
Name of the ReplicatedMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapSizeCodec.RequestParameters
Name of the ReplicatedMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapValuesCodec.RequestParameters
Name of the ReplicatedMap
name - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferAddAllCodec.RequestParameters
Name of the Ringbuffer
name - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferAddCodec.RequestParameters
Name of the Ringbuffer
name - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferCapacityCodec.RequestParameters
Name of the Ringbuffer
name - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferHeadSequenceCodec.RequestParameters
Name of the Ringbuffer
name - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferReadManyCodec.RequestParameters
Name of the Ringbuffer
name - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferReadOneCodec.RequestParameters
Name of the Ringbuffer
name - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferRemainingCapacityCodec.RequestParameters
Name of the Ringbuffer
name - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferSizeCodec.RequestParameters
Name of the Ringbuffer
name - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferTailSequenceCodec.RequestParameters
Name of the Ringbuffer
name - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreAcquireCodec.RequestParameters
Name of this ISemaphore instance
name - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreAvailablePermitsCodec.RequestParameters
Name of this ISemaphore instance
name - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreChangeCodec.RequestParameters
Name of this ISemaphore instance
name - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreDrainCodec.RequestParameters
Name of this ISemaphore instance
name - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreInitCodec.RequestParameters
Name of this ISemaphore instance
name - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreReleaseCodec.RequestParameters
Name of this ISemaphore instance
name - Variable in class com.hazelcast.client.impl.protocol.codec.SetAddAllCodec.RequestParameters
Name of the Set
name - Variable in class com.hazelcast.client.impl.protocol.codec.SetAddCodec.RequestParameters
Name of the Set
name - Variable in class com.hazelcast.client.impl.protocol.codec.SetAddListenerCodec.RequestParameters
Name of the Set
name - Variable in class com.hazelcast.client.impl.protocol.codec.SetClearCodec.RequestParameters
Name of the Set
name - Variable in class com.hazelcast.client.impl.protocol.codec.SetCompareAndRemoveAllCodec.RequestParameters
Name of the Set
name - Variable in class com.hazelcast.client.impl.protocol.codec.SetCompareAndRetainAllCodec.RequestParameters
Name of the Set
name - Variable in class com.hazelcast.client.impl.protocol.codec.SetContainsAllCodec.RequestParameters
Name of the Set
name - Variable in class com.hazelcast.client.impl.protocol.codec.SetContainsCodec.RequestParameters
Name of the Set
name - Variable in class com.hazelcast.client.impl.protocol.codec.SetGetAllCodec.RequestParameters
Name of the Set
name - Variable in class com.hazelcast.client.impl.protocol.codec.SetIsEmptyCodec.RequestParameters
Name of the Set
name - Variable in class com.hazelcast.client.impl.protocol.codec.SetRemoveCodec.RequestParameters
Name of the Set
name - Variable in class com.hazelcast.client.impl.protocol.codec.SetRemoveListenerCodec.RequestParameters
Name of the Set
name - Variable in class com.hazelcast.client.impl.protocol.codec.SetSizeCodec.RequestParameters
Name of the Set
name - Variable in class com.hazelcast.client.impl.protocol.codec.TopicAddMessageListenerCodec.RequestParameters
Name of the Topic
name - Variable in class com.hazelcast.client.impl.protocol.codec.TopicPublishCodec.RequestParameters
Name of the Topic
name - Variable in class com.hazelcast.client.impl.protocol.codec.TopicRemoveMessageListenerCodec.RequestParameters
Name of the Topic
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListAddCodec.RequestParameters
Name of the Transactional List
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListRemoveCodec.RequestParameters
Name of the Transactional List
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListSizeCodec.RequestParameters
Name of the Transactional List
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsKeyCodec.RequestParameters
Name of the Transactional Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsValueCodec.RequestParameters
Name of the Transactional Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapDeleteCodec.RequestParameters
Name of the Transactional Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetCodec.RequestParameters
Name of the Transactional Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetForUpdateCodec.RequestParameters
Name of the Transactional Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapIsEmptyCodec.RequestParameters
Name of the Transactional Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetCodec.RequestParameters
Name of the Transactional Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetWithPredicateCodec.RequestParameters
Name of the Transactional Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutCodec.RequestParameters
Name of the Transactional Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutIfAbsentCodec.RequestParameters
Name of the Transactional Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveCodec.RequestParameters
Name of the Transactional Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveIfSameCodec.RequestParameters
Name of the Transactional Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceCodec.RequestParameters
Name of the Transactional Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceIfSameCodec.RequestParameters
Name of the Transactional Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSetCodec.RequestParameters
Name of the Transactional Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSizeCodec.RequestParameters
Name of the Transactional Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesCodec.RequestParameters
Name of the Transactional Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesWithPredicateCodec.RequestParameters
Name of the Transactional Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapGetCodec.RequestParameters
Name of the Transactional Multi Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapPutCodec.RequestParameters
Name of the Transactional Multi Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveCodec.RequestParameters
Name of the Transactional Multi Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveEntryCodec.RequestParameters
Name of the Transactional Multi Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapSizeCodec.RequestParameters
Name of the Transactional Multi Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapValueCountCodec.RequestParameters
Name of the Transactional Multi Map
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueOfferCodec.RequestParameters
Name of the Transcational Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePeekCodec.RequestParameters
Name of the Transactional Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePollCodec.RequestParameters
Name of the Transactional Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueSizeCodec.RequestParameters
Name of the Transactional Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueTakeCodec.RequestParameters
Name of the Transactional Queue
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetAddCodec.RequestParameters
Name of the Transactional Set
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetRemoveCodec.RequestParameters
Name of the Transactional Set
name - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetSizeCodec.RequestParameters
Name of the Transactional Set
name - Variable in class com.hazelcast.client.impl.spi.ClientProxy
 
name - Variable in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
name - Variable in class com.hazelcast.collection.impl.collection.CollectionContainer
 
name - Variable in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
 
name - Variable in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
 
name - Variable in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
 
name - Variable in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxySupport
 
name - Variable in class com.hazelcast.config.AbstractBasicConfig
 
name - Variable in class com.hazelcast.config.EndpointConfig
 
name() - Method in class com.hazelcast.cp.internal.CPGroupInfo
 
name - Variable in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.AbstractCountDownLatchOp
 
name() - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValue
 
name() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
 
name - Variable in class com.hazelcast.internal.crdt.pncounter.operations.AbstractPNCounterOperation
 
name() - Method in class com.hazelcast.internal.jmx.CountDownLatchMBean
 
name() - Method in class com.hazelcast.internal.jmx.ExecutorServiceMBean
 
name - Variable in class com.hazelcast.internal.journal.EventJournalReadOperation
 
name - Variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterAddAndGetCodec.RequestParameters
The name of this IAtomicLong instance.
name - Variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterDecrementAndGetCodec.RequestParameters
The name of this IAtomicLong instance.
name - Variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndAddCodec.RequestParameters
The name of this IAtomicLong instance.
name - Variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndIncrementCodec.RequestParameters
The name of this IAtomicLong instance.
name - Variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndSetCodec.RequestParameters
The name of this IAtomicLong instance.
name - Variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetCodec.RequestParameters
The name of this IAtomicLong instance.
name - Variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterIncrementAndGetCodec.RequestParameters
The name of this IAtomicLong instance.
name - Variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterSetCodec.RequestParameters
The name of this IAtomicLong instance.
name - Variable in class com.hazelcast.internal.longregister.operations.AbstractLongRegisterOperation
 
name - Variable in class com.hazelcast.internal.management.dto.ClientEndPointDTO
 
name - Variable in class com.hazelcast.internal.management.dto.ManagedExecutorDTO
 
name() - Method in class com.hazelcast.internal.metrics.jmx.JmxPublisher
 
name() - Method in class com.hazelcast.internal.metrics.managementcenter.ManagementCenterPublisher
 
name() - Method in interface com.hazelcast.internal.metrics.MetricsPublisher
Name of the publisher, only used for debugging purposes.
name - Variable in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
name() - Method in class com.hazelcast.internal.networking.ChannelOption
Returns the name
name - Variable in class com.hazelcast.map.AbstractIMapEvent
 
name - Variable in class com.hazelcast.map.impl.MapContainer
 
name - Variable in class com.hazelcast.map.impl.operation.MergeOperationFactory
 
name - Variable in class com.hazelcast.map.impl.operation.PutAllPartitionAwareOperationFactory
 
name - Variable in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
 
name - Variable in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
name - Variable in class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
 
name - Variable in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
 
name - Variable in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
 
name - Variable in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
name - Variable in class com.hazelcast.ringbuffer.impl.operations.AbstractRingBufferOperation
 
name - Variable in class com.hazelcast.spi.impl.operationservice.AbstractNamedOperation
 
named(String, Runnable) - Static method in class com.hazelcast.scheduledexecutor.impl.NamedTaskDecorator
 
named(String, Callable<V>) - Static method in class com.hazelcast.scheduledexecutor.impl.NamedTaskDecorator
 
named(String, Runnable) - Static method in class com.hazelcast.scheduledexecutor.TaskUtils
Decorate any Runnable with a NamedTask to provide naming information to scheduler.
named(String, Callable<V>) - Static method in class com.hazelcast.scheduledexecutor.TaskUtils
Decorate any Callable with a NamedTask to provide naming information to scheduler.
NAMED_JCACHE_HZ_INSTANCE - Static variable in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
System property to control whether the default Hazelcast instance, which may be started when obtaining the default CachingProvider, will have an instance name set or not.
NAMED_TASK_DECORATOR - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
NamedConfig - Interface in com.hazelcast.config
Interface for hazelcast data structures with name
namedDefaultHzInstance - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
 
NamedOperation - Interface in com.hazelcast.spi.impl.operationservice
Indicates that Operation carries the distributed data structure name that is going to work on.
NamedTask - Interface in com.hazelcast.scheduledexecutor
The NamedTask interface should be implemented by any task that needs to have an identification and enhanced atomicity upon scheduling the task.
NamedTaskDecorator<V> - Class in com.hazelcast.scheduledexecutor.impl
 
NamedThreadPoolExecutor - Class in com.hazelcast.internal.util.executor
 
NamedThreadPoolExecutor(String, int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class com.hazelcast.internal.util.executor.NamedThreadPoolExecutor
 
namePartitionSequenceList - Variable in class com.hazelcast.client.impl.protocol.codec.CacheFetchNearCacheInvalidationMetadataCodec.ResponseParameters
TODO DOC
namePartitionSequenceList - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchNearCacheInvalidationMetadataCodec.ResponseParameters
TODO DOC
names - Variable in class com.hazelcast.client.impl.protocol.codec.CacheFetchNearCacheInvalidationMetadataCodec.RequestParameters
names of the caches
names - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchNearCacheInvalidationMetadataCodec.RequestParameters
names of the maps
names() - Method in class com.hazelcast.internal.json.JsonObject
Returns a list of the names in this object in document order.
nameSelector(String) - Static method in class com.hazelcast.client.impl.ClientSelectors
Regular regex rules are applied.
namespace - Variable in class com.hazelcast.internal.journal.EventJournalReadOperation
 
namespace - Variable in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
nameWithPrefix - Variable in class com.hazelcast.cache.impl.DefaultOperationProvider
 
NANOSECONDS_IN_A_MICROSECOND - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
NATIVE_ACCESS - Static variable in class com.hazelcast.internal.memory.impl.EndiannessUtil
Accesses bytes in CPU's native address space
NATIVE_OUT_OF_MEMORY_ERROR - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
NativeMemoryConfig - Class in com.hazelcast.config
Configures native memory region.
NativeMemoryConfig() - Constructor for class com.hazelcast.config.NativeMemoryConfig
 
NativeMemoryConfig(NativeMemoryConfig) - Constructor for class com.hazelcast.config.NativeMemoryConfig
 
NativeMemoryConfig.MemoryAllocatorType - Enum in com.hazelcast.config
Type of memory allocator: STANDARD: allocate/free memory using default OS memory manager POOLED: manage memory blocks in pool
NativeOutOfMemoryError - Error in com.hazelcast.memory
Thrown when Hazelcast cannot allocate required native memory.
NativeOutOfMemoryError() - Constructor for error com.hazelcast.memory.NativeOutOfMemoryError
 
NativeOutOfMemoryError(String) - Constructor for error com.hazelcast.memory.NativeOutOfMemoryError
 
NativeOutOfMemoryError(String, Throwable) - Constructor for error com.hazelcast.memory.NativeOutOfMemoryError
 
naturalOrder() - Static method in interface com.hazelcast.internal.util.function.ComparatorEx
Serializable variant of java.util.Comparator#naturalOrder().
NavigableJsonInputAdapter - Class in com.hazelcast.internal.serialization.impl
An adapter offering utility methods over a data input containing Json content.
NavigableJsonInputAdapter() - Constructor for class com.hazelcast.internal.serialization.impl.NavigableJsonInputAdapter
 
NEAR_CACHE_BATCH_INVALIDATION - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
NEAR_CACHE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
NEAR_CACHE_PRELOADER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
NEAR_CACHE_SINGLE_INVALIDATION - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
NearCache<K,V> - Interface in com.hazelcast.internal.nearcache
NearCache is the contract point to store keys and values in underlying NearCacheRecordStore.
nearCacheConfig - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
configuration of near cache or null for none
NearCacheConfig - Class in com.hazelcast.config
Contains the configuration for a Near Cache.
NearCacheConfig() - Constructor for class com.hazelcast.config.NearCacheConfig
 
NearCacheConfig(String) - Constructor for class com.hazelcast.config.NearCacheConfig
 
NearCacheConfig(NearCacheConfig) - Constructor for class com.hazelcast.config.NearCacheConfig
 
nearCacheConfig - Variable in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
nearCacheConfig - Variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
NearCacheConfig.LocalUpdatePolicy - Enum in com.hazelcast.config
Defines how to reflect local updates to the Near Cache.
NearCacheConfigAccessor - Class in com.hazelcast.config
Accessor for the EvictionConfig of a NearCacheConfig to initialize the old default max size, if no size was configured by the user.
NearCacheConfigHolder - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
NearCacheConfigHolder(String, String, boolean, boolean, int, int, EvictionConfigHolder, boolean, String, NearCachePreloaderConfig) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.NearCacheConfigHolder
 
NearCacheConfigHolderCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
NearCacheConfigReadOnly - Class in com.hazelcast.internal.config
Contains configuration for a Near Cache (read-only).
NearCacheConfigReadOnly() - Constructor for class com.hazelcast.internal.config.NearCacheConfigReadOnly
 
NearCacheConfigReadOnly(NearCacheConfig) - Constructor for class com.hazelcast.internal.config.NearCacheConfigReadOnly
 
NearCacheDataRecord - Class in com.hazelcast.internal.nearcache.impl.record
Implementation of NearCacheRecord to store Data type objects.
NearCacheDataRecord(Data, long, long) - Constructor for class com.hazelcast.internal.nearcache.impl.record.NearCacheDataRecord
 
NearCacheDataRecordStore<K,V> - Class in com.hazelcast.internal.nearcache.impl.store
NearCacheRecordStore implementation for Near Caches with InMemoryFormat.BINARY in-memory-format.
NearCacheDataRecordStore(String, NearCacheConfig, SerializationService, ClassLoader) - Constructor for class com.hazelcast.internal.nearcache.impl.store.NearCacheDataRecordStore
 
NearCachedClientCacheProxy<K,V> - Class in com.hazelcast.client.cache.impl
An ICacheInternal implementation which handles Near Cache specific behaviour of methods.
NearCachedClientMapProxy<K,V> - Class in com.hazelcast.client.impl.proxy
A Client-side IMap implementation which is fronted by a Near Cache.
NearCachedClientMapProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
NearCachedMapProxyImpl<K,V> - Class in com.hazelcast.map.impl.proxy
A server-side IMap implementation which is fronted by a Near Cache.
NearCachedMapProxyImpl(String, MapService, NodeEngine, MapConfig) - Constructor for class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
NearCacheManager - Interface in com.hazelcast.internal.nearcache
NearCacheManager is the contract point to manage all existing NearCache instances.
NearCacheObjectRecord<V> - Class in com.hazelcast.internal.nearcache.impl.record
Implementation of NearCacheRecord to store any object type except Data.
NearCacheObjectRecord(V, long, long) - Constructor for class com.hazelcast.internal.nearcache.impl.record.NearCacheObjectRecord
 
NearCacheObjectRecordStore<K,V> - Class in com.hazelcast.internal.nearcache.impl.store
NearCacheRecordStore implementation for Near Caches with InMemoryFormat.OBJECT in-memory-format.
NearCacheObjectRecordStore(String, NearCacheConfig, SerializationService, ClassLoader) - Constructor for class com.hazelcast.internal.nearcache.impl.store.NearCacheObjectRecordStore
 
NearCachePreloader<K> - Class in com.hazelcast.internal.nearcache.impl.preloader
Loads and stores the keys from a Near Cache into a file.
NearCachePreloader(String, NearCachePreloaderConfig, NearCacheStatsImpl, SerializationService) - Constructor for class com.hazelcast.internal.nearcache.impl.preloader.NearCachePreloader
 
NearCachePreloaderConfig - Class in com.hazelcast.config
Configuration for storing and pre-loading Near Cache keys.
NearCachePreloaderConfig() - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
 
NearCachePreloaderConfig(NearCachePreloaderConfig) - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
 
NearCachePreloaderConfig(String) - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
 
NearCachePreloaderConfig(boolean, String) - Constructor for class com.hazelcast.config.NearCachePreloaderConfig
 
NearCachePreloaderConfigCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
NearCachePreloaderConfigReadOnly - Class in com.hazelcast.internal.config
 
NearCachePreloaderConfigReadOnly() - Constructor for class com.hazelcast.internal.config.NearCachePreloaderConfigReadOnly
 
NearCachePreloaderConfigReadOnly(NearCachePreloaderConfig) - Constructor for class com.hazelcast.internal.config.NearCachePreloaderConfigReadOnly
 
NearCacheRecord<V> - Interface in com.hazelcast.internal.nearcache
An expirable and evictable data object which represents a Near Cache entry.
NearCacheRecordMap<K,V extends NearCacheRecord> - Interface in com.hazelcast.internal.nearcache.impl
Contract point for all record maps to be used for storage in Near Cache.
nearCacheRecordStore - Variable in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
NearCacheRecordStore<K,V> - Interface in com.hazelcast.internal.nearcache
NearCacheRecordStore is the contract point to store keys and values as NearCacheRecord internally and to serve them.
nearCacheStats - Variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
NearCacheStats - Interface in com.hazelcast.monitor
Near Cache statistics to be used by MemberState implementations.
NearCacheStatsImpl - Class in com.hazelcast.monitor.impl
 
NearCacheStatsImpl() - Constructor for class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
NearCacheStatsImpl(NearCacheStats) - Constructor for class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
NegatablePredicate - Interface in com.hazelcast.query.impl.predicates
Predicates can implement this interface if they can convert itself into logical negation
negate() - Method in interface com.hazelcast.internal.util.function.BiPredicateEx
negate() - Method in interface com.hazelcast.internal.util.function.PredicateEx
Serializable variant of Predicate.negate().
negate() - Method in class com.hazelcast.query.impl.predicates.AndPredicate
 
negate() - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
 
negate() - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
 
negate() - Method in interface com.hazelcast.query.impl.predicates.NegatablePredicate
Create logical negation of itself.
negate() - Method in class com.hazelcast.query.impl.predicates.NotEqualPredicate
 
negate() - Method in class com.hazelcast.query.impl.predicates.NotPredicate
 
negate() - Method in class com.hazelcast.query.impl.predicates.OrPredicate
 
NEGATIVE_ARRAY_SIZE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
NEGATIVE_INFINITY - Static variable in class com.hazelcast.query.impl.CompositeValue
Represents a value that is equal to itself and less than any other value.
NEGATIVE_INFINITY - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
NETWORK_STATS_REFRESH_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
The interval at which network stats (bytes sent and received) are re-calculated and published.
NetworkConfig - Class in com.hazelcast.config
Contains configuration for Network.
NetworkConfig() - Constructor for class com.hazelcast.config.NetworkConfig
 
Networking - Interface in com.hazelcast.internal.networking
The Networking is an abstraction responsible for lower level networking services.
NetworkingImbalancePlugin - Class in com.hazelcast.internal.diagnostics
The NetworkingImbalancePlugin is an experimental plugin meant for detecting imbalance in the IO system.
NetworkingImbalancePlugin(NodeEngineImpl) - Constructor for class com.hazelcast.internal.diagnostics.NetworkingImbalancePlugin
 
NetworkingImbalancePlugin(HazelcastProperties, Networking, ILogger) - Constructor for class com.hazelcast.internal.diagnostics.NetworkingImbalancePlugin
 
networkingService - Variable in class com.hazelcast.instance.impl.Node
 
NetworkingService<T extends Connection> - Interface in com.hazelcast.internal.nio
Networking service, it initializes the endpoints, the acceptor and the reactive networking stack Given an EndpointQualifier an EndpointManager can be retrieved by NetworkingService.getEndpointManager(EndpointQualifier) to create or get connections on that end.
NetworkingServiceMBean - Class in com.hazelcast.internal.jmx
Management bean for NetworkingService
NetworkingServiceMBean(HazelcastInstance, NetworkingService, ManagementService) - Constructor for class com.hazelcast.internal.jmx.NetworkingServiceMBean
 
NetworkStats - Interface in com.hazelcast.internal.networking
Stats per EndpointManager for both directions of network traffic (inbound or outbound).
newAddedDelayedEntry(K, V, long, long, int, UUID) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntries
 
newAddedDelayedEntry(K) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntries
 
newAllowedDuringPassiveStateTransaction(TransactionOptions) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
Creates a plain transaction object which can be used while cluster state is ClusterState.PASSIVE, without wrapping it inside a TransactionContext.
newAtomicValue(CPGroupId, String, Long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongService
 
newAtomicValue(CPGroupId, String, Data) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefService
 
newAtomicValue(CPGroupId, String, T) - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueService
 
newBackupExpiryOp(ICacheRecordStore, Collection<ExpiredKey>) - Method in class com.hazelcast.cache.impl.eviction.CacheClearExpiredRecordsTask
 
newBackupExpiryOp(S, Collection<ExpiredKey>) - Method in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
newBackupExpiryOp(RecordStore, Collection<ExpiredKey>) - Method in class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
 
newBackupExpiryOpFilter() - Method in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
newBackupOperation(RecordInfo) - Method in class com.hazelcast.map.impl.operation.BasePutOperation
 
newBackupOperation(RecordInfo) - Method in class com.hazelcast.map.impl.operation.PutTransientOperation
 
newBuilder(int) - Static method in class com.hazelcast.internal.util.collection.InflatableSet
 
newBuilder(List<T>) - Static method in class com.hazelcast.internal.util.collection.InflatableSet
 
newBuilder(InternalSerializationService) - Static method in class com.hazelcast.query.impl.getters.Extractors
 
newBuilder(SerializationService, IndexCopyBehavior) - Static method in class com.hazelcast.query.impl.Indexes
 
newByteBuffer(int, boolean) - Static method in class com.hazelcast.internal.nio.IOUtil
 
newCacheReplicationOperation() - Method in class com.hazelcast.cache.impl.CacheService
 
newCallIdSequence(int, long, ConcurrencyDetection) - Static method in class com.hazelcast.spi.impl.sequence.CallIdFactory
 
newClientTransactionContext(TransactionOptions, UUID) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
newClientTransactionContext(TransactionOptions, UUID) - Method in interface com.hazelcast.transaction.TransactionManagerService
 
newCommitOperation() - Method in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
 
newCommitOperation() - Method in class com.hazelcast.collection.impl.txnqueue.QueueTransactionLogRecord
 
newCommitOperation() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateTransactionLogRecord
 
newCommitOperation() - Method in class com.hazelcast.map.impl.tx.MapTransactionLogRecord
 
newCommitOperation() - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
 
newCommitOperation() - Method in interface com.hazelcast.transaction.impl.TransactionLogRecord
 
newComparator(Comparator<Map.Entry>, IterationType) - Static method in class com.hazelcast.internal.util.SortingUtil
 
newCompletableFuture() - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Creates a new instance of SimpleCompletableFuture.
newCompletedFuture(Object) - Static method in class com.hazelcast.spi.impl.InternalCompletableFuture
Creates a new InternalCompletableFuture that is already completed with the value given as argument as its completion value.
newCompletedFuture(Object, SerializationService) - Static method in class com.hazelcast.spi.impl.InternalCompletableFuture
Creates a new InternalCompletableFuture that is already completed with the value given as argument as its completion value.
newCompletedFuture(Object, Executor) - Static method in class com.hazelcast.spi.impl.InternalCompletableFuture
Creates a new InternalCompletableFuture that is already completed with the value given as argument as its completion value and the provided defaultAsyncExecutor as the default executor for execution of next stages registered with default async methods (i.e.
newCompletedFuture(Object, SerializationService, Executor) - Static method in class com.hazelcast.spi.impl.InternalCompletableFuture
Creates a new InternalCompletableFuture that is already completed with the value given as argument as its completion value and the provided defaultAsyncExecutor as the default executor for execution of next stages registered with default async methods (i.e.
newCompositeEvictionChecker(CompositeEvictionChecker.CompositionOperator, EvictionChecker...) - Static method in class com.hazelcast.internal.eviction.CompositeEvictionChecker
 
newCondition() - Method in class com.hazelcast.client.cp.internal.datastructures.lock.FencedLockProxy
 
newCondition() - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
newCondition() - Method in interface com.hazelcast.cp.lock.FencedLock
NOT IMPLEMENTED.
newConfigFor(String) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Creates new AliasedDiscoveryConfig by the given tag.
newCredentials() - Method in class com.hazelcast.config.security.StaticCredentialsFactory
 
newCredentials() - Method in interface com.hazelcast.security.ICredentialsFactory
Creates new Credentials object.
newDelegatingFuture(SerializationService, InternalCompletableFuture<Data>) - Static method in class com.hazelcast.spi.impl.InternalCompletableFuture
Creates a new InternalCompletableFuture that delegates to the given future and deserializes its completion value of type Data.
newDeletedEntry(K, long, int, UUID) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntries
 
newDiscoveryService(DiscoveryServiceSettings) - Method in class com.hazelcast.spi.discovery.impl.DefaultDiscoveryServiceProvider
 
newDiscoveryService(DiscoveryServiceSettings) - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryServiceProvider
Instantiates a new instance of the DiscoveryService.
newDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategyFactory
Instantiates a new instance of the DiscoveryStrategy with the given configuration properties.
newDiscoveryStrategy(DiscoveryNode, ILogger, Map<String, Comparable>) - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategyFactory
 
newDoubleGauge(String) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
 
newDoubleGauge(String) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
Creates a DoubleGauge for a given metric name.
newEndToEndConstructor(QueryCacheRequest) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientSubscriberContext
 
newEndToEndConstructor(QueryCacheRequest) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeSubscriberContext
 
newEndToEndConstructor(QueryCacheRequest) - Method in interface com.hazelcast.map.impl.querycache.subscriber.SubscriberContext
 
newEntry(Data, Object) - Method in class com.hazelcast.map.impl.query.QueryEntryFactory
 
newestSequence(ObjectNamespace, int) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
 
newestSequence - Variable in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalSubscribeCodec.ResponseParameters
TODO DOC
newestSequence - Variable in class com.hazelcast.client.impl.protocol.codec.MapEventJournalSubscribeCodec.ResponseParameters
TODO DOC
newestSequence(ObjectNamespace, int) - Method in interface com.hazelcast.internal.journal.EventJournal
Returns the sequence of the newest event stored in the event journal.
newestSequence(ObjectNamespace, int) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
 
newFieldGetter(Object, Getter, Field, String) - Static method in class com.hazelcast.query.impl.getters.GetterFactory
 
newHazelcastClient() - Static method in class com.hazelcast.client.HazelcastClient
Creates a new HazelcastInstance (a new client in a cluster).
newHazelcastClient(ClientConfig) - Static method in class com.hazelcast.client.HazelcastClient
Creates a new HazelcastInstance (a new client in a cluster).
newHazelcastFailoverClient() - Static method in class com.hazelcast.client.HazelcastClient
Creates a client with cluster switch capability.
newHazelcastFailoverClient(ClientFailoverConfig) - Static method in class com.hazelcast.client.HazelcastClient
Creates a client with cluster switch capability.
newHazelcastInstance(Config) - Static method in class com.hazelcast.core.Hazelcast
Creates a new HazelcastInstance (a new node in a cluster).
newHazelcastInstance() - Static method in class com.hazelcast.core.Hazelcast
Creates a new HazelcastInstance (a new node in a cluster).
newHazelcastInstance(Config) - Static method in class com.hazelcast.instance.impl.HazelcastInstanceFactory
Creates a new Hazelcast instance.
newHazelcastInstance(Config, String, NodeContext) - Static method in class com.hazelcast.instance.impl.HazelcastInstanceFactory
Creates a new Hazelcast instance.
newHazelcastInstance(Config) - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Creates a new HazelcastOSGiInstance on the owner bundle with specified configuration.
newHazelcastInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Creates a new HazelcastOSGiInstance on the owner bundle with default configuration.
newId() - Method in class com.hazelcast.client.impl.proxy.ClientFlakeIdGeneratorProxy
 
newId() - Method in interface com.hazelcast.flakeidgen.FlakeIdGenerator
Generates and returns a cluster-wide unique ID.
newId() - Method in class com.hazelcast.flakeidgen.impl.AutoBatcher
Return next ID from current batch or get new batch from supplier if current batch is spent or expired.
newId() - Method in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorProxy
 
newIdBatch(int) - Method in interface com.hazelcast.flakeidgen.impl.AutoBatcher.IdBatchSupplier
 
newIdBatch(int) - Method in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorProxy
 
NewIdBatchMessageTask - Class in com.hazelcast.flakeidgen.impl.client
 
NewIdBatchMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.flakeidgen.impl.client.NewIdBatchMessageTask
 
newImmutableSetBuilder(int) - Static method in class com.hazelcast.internal.util.collection.ImmutableInflatableSet
 
newInputStream(ByteBuffer) - Static method in class com.hazelcast.internal.nio.IOUtil
 
newInstance(ClassLoader, String) - Static method in class com.hazelcast.internal.nio.ClassLoaderUtil
Creates a new instance of class with className, using the no-arg constructor.
newInstance() - Static method in class com.hazelcast.internal.util.filter.AlwaysApplyFilter
 
newInstanceOrNull(Class<? extends T>, Object...) - Static method in class com.hazelcast.internal.util.InstantiationUtils
Create a new instance of a given class.
newInvalidation(Data, String, UUID, int) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.BatchInvalidator
 
newInvalidation(Data, String, UUID, int) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
 
newJsonPathCursor() - Method in class com.hazelcast.query.impl.getters.JsonGetterContext
 
newLoggerFactory(String) - Static method in class com.hazelcast.logging.Logger
Creates a logger factory instance of the given preferred type.
newLongGauge(String) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
 
newLongGauge(String) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
Creates a LongGauge for a given metric name.
newMapListener() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapAddEntryListenerMessageTask
 
newMapListener() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddNearCacheInvalidationListenerMessageTask
 
newMapListener() - Method in class com.hazelcast.client.impl.protocol.task.map.Pre38MapAddNearCacheEntryListenerMessageTask
 
newMapStore(String, Properties) - Method in interface com.hazelcast.map.MapStoreFactory
Produces a MapLoader or a MapStore for the given map name and properties.
newMBeanServer(String, MBeanServer, MBeanServerDelegate) - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder
 
newMemberGroupFactory(PartitionGroupConfig, DiscoveryService) - Static method in class com.hazelcast.partition.membergroup.MemberGroupFactoryFactory
 
newMergeRunnable(Collection<Store>) - Method in class com.hazelcast.spi.impl.merge.AbstractSplitBrainHandlerService
Returns a runnable which merges the given Store instances.
newMethodGetter(Object, Getter, Method, String) - Static method in class com.hazelcast.query.impl.getters.GetterFactory
 
newMetricTagger() - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
 
newMetricTagger(String) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
 
newMetricTagger() - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
Creates a new MetricTagger.
newMetricTagger(String) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
Creates a new MetricTagger with the given metric name prefix.
newMwCounter() - Static method in class com.hazelcast.internal.util.counters.MwCounter
Creates a new MwCounter with 0 as its initial value.
newMwCounter(long) - Static method in class com.hazelcast.internal.util.counters.MwCounter
Creates a new MwCounter with the given initial value.
newNullEntry(K) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntries
 
newObjectInputStream(ClassLoader, ClassNameFilter, InputStream) - Static method in class com.hazelcast.internal.nio.IOUtil
 
newOptimizer(HazelcastProperties) - Static method in class com.hazelcast.query.impl.predicates.QueryOptimizerFactory
Creates new QueryOptimizer.
newOutputStream(ByteBuffer) - Static method in class com.hazelcast.internal.nio.IOUtil
 
newPartitionSegment(int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
newPartitionSegment(int) - Method in class com.hazelcast.cache.impl.CacheService
 
newPermissionCollection() - Method in class com.hazelcast.security.permission.AllPermissions
 
newPermissionCollection() - Method in class com.hazelcast.security.permission.ClusterPermission
 
newPredicateBuilder() - Static method in class com.hazelcast.query.Predicates
Creates a new instance of PredicateBuilder.
newPrepareOperation() - Method in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
 
newPrepareOperation() - Method in class com.hazelcast.collection.impl.txnqueue.QueueTransactionLogRecord
 
newPrepareOperation() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateTransactionLogRecord
 
newPrepareOperation() - Method in class com.hazelcast.map.impl.tx.MapTransactionLogRecord
 
newPrepareOperation() - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
 
newPrepareOperation() - Method in interface com.hazelcast.transaction.impl.TransactionLogRecord
 
newPrimaryExpiryOp(int, CachePartitionSegment) - Method in class com.hazelcast.cache.impl.eviction.CacheClearExpiredRecordsTask
 
newPrimaryExpiryOp(int, T) - Method in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
newPrimaryExpiryOp(int, PartitionContainer) - Method in class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
 
newProbabilisticSplitBrainProtectionConfigBuilder(String, int) - Static method in class com.hazelcast.config.SplitBrainProtectionConfig
Returns a builder for SplitBrainProtectionConfig with the given name using a probabilistic split brain protection function, for the given split brain protection size that is enabled by default.
newProbe(String, String, String) - Method in class com.hazelcast.internal.diagnostics.StoreLatencyPlugin
 
newQueryCacheEventDataBuilder(boolean) - Static method in class com.hazelcast.map.impl.querycache.event.QueryCacheEventDataBuilder
 
newQueryCacheRequest() - Static method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRequest
 
newQueryEntry(Data, Object) - Method in class com.hazelcast.map.impl.MapContainer
 
newQueueStore(String, Properties) - Method in interface com.hazelcast.collection.QueueStoreFactory
 
newRaftAtomicProxy(NodeEngineImpl, RaftGroupId, String, String) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongService
 
newRaftAtomicProxy(NodeEngineImpl, RaftGroupId, String, String) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefService
 
newRaftAtomicProxy(NodeEngineImpl, RaftGroupId, String, String) - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueService
 
newRaftLog(int) - Static method in class com.hazelcast.cp.internal.raft.impl.log.RaftLog
 
newRaftLog(int, RaftStateStore) - Static method in class com.hazelcast.cp.internal.raft.impl.log.RaftLog
 
newRaftNode(CPGroupId, RaftEndpoint, Collection<RaftEndpoint>, RaftAlgorithmConfig, RaftIntegration) - Static method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Creates a new Raft node with an empty initial state.
newRaftNode(CPGroupId, RaftEndpoint, Collection<RaftEndpoint>, RaftAlgorithmConfig, RaftIntegration, RaftStateStore) - Static method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Creates a new Raft node with an empty initial state and a RaftStateStore to persist Raft state changes
newRaftState(CPGroupId, RaftEndpoint, Collection<RaftEndpoint>, int) - Static method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
 
newRaftState(CPGroupId, RaftEndpoint, Collection<RaftEndpoint>, int, RaftStateStore) - Static method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
 
newRecentlyActiveSplitBrainProtectionConfigBuilder(String, int, int) - Static method in class com.hazelcast.config.SplitBrainProtectionConfig
Returns a builder for a SplitBrainProtectionConfig with the given name using a recently-active split brain protection function for the given split brain protection size that is enabled by default.
newRecord(Data, Object) - Method in class com.hazelcast.map.impl.record.DataRecordFactory
 
newRecord(Data, Object) - Method in class com.hazelcast.map.impl.record.ObjectRecordFactory
 
newRecord(Data, Object) - Method in interface com.hazelcast.map.impl.record.RecordFactory
 
newRecordWithExpiry(Object, long, long) - Method in class com.hazelcast.cache.impl.record.CacheRecordFactory
 
newRepairingHandler(String, NearCache) - Method in class com.hazelcast.map.impl.nearcache.MapNearCacheManager
 
newRingbufferStore(String, Properties) - Method in interface com.hazelcast.ringbuffer.RingbufferStoreFactory
 
newRollbackOperation() - Method in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
 
newRollbackOperation() - Method in class com.hazelcast.collection.impl.txnqueue.QueueTransactionLogRecord
 
newRollbackOperation() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateTransactionLogRecord
 
newRollbackOperation() - Method in class com.hazelcast.map.impl.tx.MapTransactionLogRecord
 
newRollbackOperation() - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
 
newRollbackOperation() - Method in interface com.hazelcast.transaction.impl.TransactionLogRecord
 
newScheduler(TaskScheduler, ScheduledEntryProcessor<K, V>, ScheduleType) - Static method in class com.hazelcast.internal.util.scheduler.EntryTaskSchedulerFactory
Creates a new EntryTaskScheduler that will run all second operations in bulk.
newSecureUUID() - Static method in class com.hazelcast.internal.util.UuidUtil
Static factory to retrieve a type 4 (pseudo randomly generated) UUID.
newSecureUuidString() - Static method in class com.hazelcast.internal.util.UuidUtil
Static factory to retrieve a type 4 (pseudo randomly generated) UUID based string.
newSnapshot(Map<String, Long>, Set<String>) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongService
 
newSnapshot(Map<String, Data>, Set<String>) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefService
 
newSnapshot(Map<String, T>, Set<String>) - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueService
 
newSwCounter() - Static method in class com.hazelcast.internal.util.counters.SwCounter
Creates a new SwCounter with 0 as initial value.
newSwCounter(long) - Static method in class com.hazelcast.internal.util.counters.SwCounter
Creates a new SwCounter with the given initial value.
newThisGetter(Getter, Object) - Static method in class com.hazelcast.query.impl.getters.GetterFactory
 
newThread(Runnable) - Method in class com.hazelcast.internal.util.concurrent.ThreadFactoryImpl
 
newThread(Runnable) - Method in class com.hazelcast.internal.util.executor.AbstractExecutorThreadFactory
 
newTimeoutException(long, TimeUnit) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
newTimeoutException(long, TimeUnit) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
newTimeoutException(long, TimeUnit) - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationFuture
 
newTransactionContext() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
newTransactionContext(TransactionOptions) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
newTransactionContext() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
newTransactionContext(TransactionOptions) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
newTransactionContext() - Method in interface com.hazelcast.client.impl.spi.ClientTransactionManagerService
 
newTransactionContext(TransactionOptions) - Method in interface com.hazelcast.client.impl.spi.ClientTransactionManagerService
 
newTransactionContext() - Method in class com.hazelcast.client.impl.spi.impl.ClientTransactionManagerServiceImpl
 
newTransactionContext(TransactionOptions) - Method in class com.hazelcast.client.impl.spi.impl.ClientTransactionManagerServiceImpl
 
newTransactionContext() - Method in interface com.hazelcast.core.HazelcastInstance
Creates a new TransactionContext associated with the current thread using default options.
newTransactionContext(TransactionOptions) - Method in interface com.hazelcast.core.HazelcastInstance
Creates a new TransactionContext associated with the current thread with given options.
newTransactionContext() - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
newTransactionContext(TransactionOptions) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
newTransactionContext() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
newTransactionContext(TransactionOptions) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
newTransactionContext(TransactionOptions) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
newTransactionContext(TransactionOptions) - Method in interface com.hazelcast.transaction.TransactionManagerService
 
newUnsecureUUID() - Static method in class com.hazelcast.internal.util.UuidUtil
Static factory to retrieve a type 4 (pseudo randomly generated) UUID.
newUnsecureUuidString() - Static method in class com.hazelcast.internal.util.UuidUtil
Static factory to retrieve a type 4 (pseudo randomly generated) UUID based string.
newValue - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndSetCodec.RequestParameters
The new value
newValue - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefCompareAndSetCodec.RequestParameters
The new value
newValue - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefSetCodec.RequestParameters
The value to set
newValue - Variable in class com.hazelcast.client.impl.protocol.codec.CacheReplaceCodec.RequestParameters
The new value to be associated with the specified key.
newValue - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceIfSameCodec.RequestParameters
The new value to replace the old value.
newValue - Variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndSetCodec.RequestParameters
the new value
newValue - Variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterSetCodec.RequestParameters
The new value
newValue - Variable in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
 
newXATransactionContext(Xid, int) - Method in interface com.hazelcast.client.impl.spi.ClientTransactionManagerService
 
newXATransactionContext(Xid, int) - Method in class com.hazelcast.client.impl.spi.impl.ClientTransactionManagerServiceImpl
 
newXATransactionContext(Xid, UUID, int, boolean) - Method in class com.hazelcast.transaction.impl.xa.XAService
 
next() - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
next() - Method in class com.hazelcast.client.impl.clientside.ClientDiscoveryService
 
next() - Method in class com.hazelcast.client.impl.protocol.ClientMessage.ForwardFrameIterator
 
next() - Method in interface com.hazelcast.client.LoadBalancer
Returns the next member to route to.
next() - Method in class com.hazelcast.client.util.RandomLB
 
next() - Method in class com.hazelcast.client.util.RoundRobinLB
 
next() - Method in class com.hazelcast.client.util.StaticLB
 
next() - Method in class com.hazelcast.collection.impl.queue.QueueIterator
 
next() - Method in class com.hazelcast.durableexecutor.impl.TaskRingBuffer.DurableIterator
 
next() - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap.KeyIterator
 
next() - Method in class com.hazelcast.internal.util.collection.IntIterator
 
next() - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap.LongIterator
 
next() - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap.KeyIterator
 
next() - Method in class com.hazelcast.internal.util.collection.LongIterator
 
next() - Method in class com.hazelcast.internal.util.iterator.RestartingMemberIterator
 
next(T) - Method in class com.hazelcast.internal.util.StateMachine
Transition to next state
next() - Method in class com.hazelcast.map.impl.iterator.AbstractMapPartitionIterator
 
next() - Method in class com.hazelcast.map.impl.iterator.AbstractMapQueryPartitionIterator
 
next() - Method in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore.ReadOnlyRecordIterator
 
next() - Method in class com.hazelcast.ringbuffer.impl.ReadOnlyRingbufferIterator
 
next() - Method in class com.hazelcast.spi.impl.merge.AbstractContainerCollector.EmptyIterator
 
next() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.TaskBatch
Gets the next task to execute.
next() - Method in class com.hazelcast.spi.impl.sequence.AbstractCallIdSequence
 
next() - Method in interface com.hazelcast.spi.impl.sequence.CallIdSequence
Generates the next unique call ID.
next() - Method in class com.hazelcast.spi.impl.sequence.CallIdSequenceWithoutBackpressure
 
next() - Method in class com.hazelcast.spi.merge.RingbufferMergeDataReadOnlyIterator
 
next() - Method in class com.hazelcast.topic.impl.reliable.MessageRunner
 
nextCapacity(int) - Static method in class com.hazelcast.internal.util.hashslot.impl.CapacityUtil
Returns the next possible capacity, counting from the current buffers' size.
nextCapacity(long) - Static method in class com.hazelcast.internal.util.hashslot.impl.CapacityUtil
Returns the next possible capacity, counting from the current buffers' size.
nextFrameIsDataStructureEndFrame(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.CodecUtil
 
nextFrameIsNullEndFrame(ClientMessage.ForwardFrameIterator) - Static method in class com.hazelcast.client.impl.protocol.codec.builtin.CodecUtil
 
nextId() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
nextId() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
nextIndex() - Method in class com.hazelcast.cp.internal.raft.impl.state.FollowerState
Returns the next index for follower.
nextIndex(long) - Method in class com.hazelcast.cp.internal.raft.impl.state.FollowerState
Sets the next index for follower.
nextInt() - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap.KeyIterator
Non-boxing variant of next().
nextLine - Variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
nextLong() - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap.KeyIterator
Non-boxing variant of next().
nextOrStay(T) - Method in class com.hazelcast.internal.util.StateMachine
Transition to next state if not already there
nextPage() - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
 
nextPage() - Method in interface com.hazelcast.query.PagingPredicate
Sets the page value to next page.
nextPowerOfTwo(int) - Static method in class com.hazelcast.internal.util.QuickMath
Fast method of finding the next power of 2 greater than or equal to the supplied value.
nextPowerOfTwo(long) - Static method in class com.hazelcast.internal.util.QuickMath
Fast method of finding the next power of 2 greater than or equal to the supplied value.
nextSeq - Variable in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalReadCodec.ResponseParameters
TODO DOC
nextSeq - Variable in class com.hazelcast.client.impl.protocol.codec.MapEventJournalReadCodec.ResponseParameters
TODO DOC
nextSeq - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferReadManyCodec.ResponseParameters
TODO DOC
nextSequence - Variable in class com.hazelcast.client.impl.protocol.codec.MetricsReadMetricsCodec.ResponseParameters
The sequence number that the next task should start with
nextSequence() - Method in class com.hazelcast.internal.metrics.managementcenter.ConcurrentArrayRingbuffer.RingbufferSlice
The tail, this is the sequence where next call to ConcurrentArrayRingbuffer.copyFrom(long) should start.
nextSequence() - Method in class com.hazelcast.internal.metrics.managementcenter.MetricsResultSet
The next sequence to read from.
nextSequence(String, int) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataGenerator
 
nextSequence() - Method in class com.hazelcast.map.impl.querycache.event.sequence.DefaultPartitionSequencer
 
nextSequence() - Method in interface com.hazelcast.map.impl.querycache.event.sequence.PartitionSequencer
Returns next number in sequence for the partition.
nextTableIndexToReadFrom - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchWithQueryCodec.ResponseParameters
TODO DOC
nextTerm() - Method in class com.hazelcast.cp.internal.raft.impl.dto.PreVoteRequest
 
nextUnsafeModeCommitIndex(CPGroupId) - Method in class com.hazelcast.cp.internal.RaftService
 
nextValue() - Method in class com.hazelcast.internal.util.collection.IntIterator
Strongly typed alternative of Iterator.next() to avoid boxing.
nextValue() - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap.LongIterator
Non-boxing variant of next().
nextValue() - Method in class com.hazelcast.internal.util.collection.LongIterator
Strongly typed alternative of Iterator.next() not to avoid boxing.
NIL_UUID - Static variable in class com.hazelcast.internal.util.UuidUtil
The nil UUID is special form of UUID that is specified to have all 128 bits set to zero as described in the RFC 4122.
NioChannel - Class in com.hazelcast.internal.networking.nio
A Channel implementation tailored for non blocking IO using Selector in combination with a non blocking SocketChannel.
NioChannel(SocketChannel, boolean, ChannelInitializer, Executor) - Constructor for class com.hazelcast.internal.networking.nio.NioChannel
 
NioInboundPipeline - Class in com.hazelcast.internal.networking.nio
When the NioThread receives a read event from the Selector, then the NioInboundPipeline.process() is called to read out the data from the socket into a bytebuffer and hand it over to the InboundHandler to get processed.
NioNetworking - Class in com.hazelcast.internal.networking.nio
A non blocking Networking implementation that makes use of Selector to have a limited set of io threads, handle an arbitrary number of connections.
NioNetworking(NioNetworking.Context) - Constructor for class com.hazelcast.internal.networking.nio.NioNetworking
 
NioNetworking.Context - Class in com.hazelcast.internal.networking.nio
 
NioOutboundPipeline - Class in com.hazelcast.internal.networking.nio
 
NioOutboundPipeline.State - Enum in com.hazelcast.internal.networking.nio
 
NioPipeline - Class in com.hazelcast.internal.networking.nio
 
NioThread - Class in com.hazelcast.internal.networking.nio
 
NioThread(String, ILogger, ChannelErrorHandler) - Constructor for class com.hazelcast.internal.networking.nio.NioThread
 
NioThread(String, ILogger, ChannelErrorHandler, SelectorMode, IdleStrategy) - Constructor for class com.hazelcast.internal.networking.nio.NioThread
 
NioThread(String, ILogger, ChannelErrorHandler, SelectorMode, Selector, IdleStrategy) - Constructor for class com.hazelcast.internal.networking.nio.NioThread
 
NO_DATA_MEMBER - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
NO_LISTENER - Static variable in interface com.hazelcast.internal.eviction.EvictionListener
Empty EvictionListener
NO_OFFLOADING - Static variable in interface com.hazelcast.core.Offloadable
Constant meaning that there will be no off-loading if returned from the Offloadable.getExecutorName() method.
NO_SEQUENCE - Static variable in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationUtils
 
NO_SESSION_ID - Static variable in class com.hazelcast.cp.internal.session.AbstractProxySessionManager
Represents absence of a Raft session
NO_SUCH_ELEMENT - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
NO_TIME_SET - Static variable in class com.hazelcast.map.EntryLoader.MetadataAwareValue
Represents no expiration time for a particular value
NoDataMemberInClusterException - Exception in com.hazelcast.partition
Thrown when there is no data member in the cluster to assign partitions.
NoDataMemberInClusterException(String) - Constructor for exception com.hazelcast.partition.NoDataMemberInClusterException
 
node(String, Object, Object...) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
node - Variable in class com.hazelcast.instance.impl.DefaultNodeExtension
 
node - Variable in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
Node - Class in com.hazelcast.instance.impl
 
Node(HazelcastInstanceImpl, Config, NodeContext) - Constructor for class com.hazelcast.instance.impl.Node
 
node - Variable in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
Node.NodeShutdownHookThread - Class in com.hazelcast.instance.impl
 
NodeAware - Interface in com.hazelcast.internal.services
A 'capability' that can be implemented by object to get the Node injected.
NodeContext - Interface in com.hazelcast.instance.impl
A context for node to provide its dependencies.
nodeEngine - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
nodeEngine - Variable in class com.hazelcast.cache.impl.AbstractCacheService
 
nodeEngine - Variable in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
nodeEngine - Variable in class com.hazelcast.collection.impl.collection.CollectionContainer
 
nodeEngine - Variable in class com.hazelcast.collection.impl.collection.CollectionService
 
nodeEngine - Variable in class com.hazelcast.cp.internal.datastructures.spi.AbstractCPMigrationAwareService
 
nodeEngine - Variable in class com.hazelcast.instance.impl.Node
 
nodeEngine - Variable in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
nodeEngine - Variable in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
 
nodeEngine - Variable in class com.hazelcast.internal.partition.impl.AbstractPartitionPrimaryReplicaAntiEntropyTask
 
nodeEngine - Variable in class com.hazelcast.map.impl.event.MapEventPublisherImpl
 
nodeEngine - Variable in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
 
nodeEngine - Variable in class com.hazelcast.map.impl.nearcache.MapNearCacheManager
 
nodeEngine - Variable in class com.hazelcast.map.impl.query.PartitionScanRunner
 
nodeEngine - Variable in class com.hazelcast.map.impl.query.QueryRunner
 
nodeEngine - Variable in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
NodeEngine - Interface in com.hazelcast.spi.impl
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a ManagedService.
nodeEngine - Variable in class com.hazelcast.spi.impl.operationservice.Offload
 
NodeEngineImpl - Class in com.hazelcast.spi.impl
The NodeEngineImpl is the where the construction of the Hazelcast dependencies take place.
NodeEngineImpl(Node) - Constructor for class com.hazelcast.spi.impl.NodeEngineImpl
 
NodeEngineImpl.JetPacketConsumer - Interface in com.hazelcast.spi.impl
 
NodeExtension - Interface in com.hazelcast.instance.impl
NodeExtension is a Node extension mechanism to be able to plug different implementations of some modules, like; SerializationService, ChannelFactory etc.
NodeExtensionFactory - Class in com.hazelcast.instance.impl
 
NodeFilter - Interface in com.hazelcast.spi.discovery
The NodeFilter, if supplied, will retrieve all discovered nodes and might apply additional filtering based on vendor provided metadata.
nodeIdOffset - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddFlakeIdGeneratorConfigCodec.RequestParameters
TODO DOC
NodeIdOutOfRangeException - Exception in com.hazelcast.flakeidgen.impl
Exception thrown from member if that member is not able to generate IDs using Flake ID generator because its node ID is too big.
NodeIdOutOfRangeException(String) - Constructor for exception com.hazelcast.flakeidgen.impl.NodeIdOutOfRangeException
 
nodeIfContents(String, Object, Object...) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
NodeInvokerWrapper - Class in com.hazelcast.map.impl.querycache
Invocation functionality for node-side QueryCacheContext.
NodeIOService - Class in com.hazelcast.internal.nio
 
NodeIOService(Node, NodeEngineImpl) - Constructor for class com.hazelcast.internal.nio.NodeIOService
 
NODEJS - Static variable in class com.hazelcast.client.impl.ClientTypes
Node.JS client protocol ID
NodeMBean - Class in com.hazelcast.internal.jmx
Management bean for Node
NodeMBean(HazelcastInstance, Node, ManagementService) - Constructor for class com.hazelcast.internal.jmx.NodeMBean
 
NodeMulticastListener - Class in com.hazelcast.internal.cluster.impl
 
NodeMulticastListener(Node) - Constructor for class com.hazelcast.internal.cluster.impl.NodeMulticastListener
 
nodeName() - Method in class com.hazelcast.internal.yaml.AbstractYamlNode
 
nodeName() - Method in class com.hazelcast.internal.yaml.YamlNameNodePair
Returns the name of the node
nodeName() - Method in interface com.hazelcast.internal.yaml.YamlNode
Returns the name of the node
NodeQueryCacheConfigurator - Class in com.hazelcast.map.impl.querycache.subscriber
Node side implementation of QueryCacheConfigurator.
NodeQueryCacheConfigurator(Config, ClassLoader, QueryCacheEventService) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheConfigurator
 
NodeQueryCacheContext - Class in com.hazelcast.map.impl.querycache
Node side implementation of QueryCacheContext.
NodeQueryCacheContext(MapServiceContext) - Constructor for class com.hazelcast.map.impl.querycache.NodeQueryCacheContext
 
NodeQueryCacheEndToEndConstructor - Class in com.hazelcast.map.impl.querycache.subscriber
Node-side implementation of QueryCacheEndToEndConstructor.
NodeQueryCacheEndToEndConstructor(QueryCacheRequest) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheEndToEndConstructor
 
NodeQueryCacheEventService - Class in com.hazelcast.map.impl.querycache.subscriber
Node side event service implementation for query cache.
NodeQueryCacheEventService(MapServiceContext, ContextMutexFactory) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheEventService
 
NodeQueryCacheScheduler - Class in com.hazelcast.map.impl.querycache.subscriber
Node side implementation of QueryCacheScheduler.
NodeQueryCacheScheduler(MapServiceContext) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheScheduler
 
NodeShutdownHelper - Class in com.hazelcast.instance.impl
Helper methods for node shutdown scenarios.
NodeState - Enum in com.hazelcast.instance.impl
Possible states of a Node during its lifecycle.
NodeState - Interface in com.hazelcast.monitor
Local node statistics to be used by MemberState implementations.
NodeStateImpl - Class in com.hazelcast.monitor.impl
 
NodeStateImpl() - Constructor for class com.hazelcast.monitor.impl.NodeStateImpl
 
NodeStateImpl(ClusterState, NodeState, Version, MemberVersion) - Constructor for class com.hazelcast.monitor.impl.NodeStateImpl
 
NodeStateImpl(ClusterState, NodeState, Version, MemberVersion, Map<String, List<String>>) - Constructor for class com.hazelcast.monitor.impl.NodeStateImpl
 
NodeSubscriberContext - Class in com.hazelcast.map.impl.querycache.subscriber
Node side implementation of SubscriberContext.
NodeSubscriberContext(QueryCacheContext) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.NodeSubscriberContext
 
NodeSubscriberContextSupport - Class in com.hazelcast.map.impl.querycache.subscriber
SubscriberContextSupport implementation for node side.
NodeSubscriberContextSupport(InternalSerializationService) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.NodeSubscriberContextSupport
 
nodeValue() - Method in interface com.hazelcast.internal.yaml.YamlScalar
Gets the value of the node
nodeValue(Class<T>) - Method in interface com.hazelcast.internal.yaml.YamlScalar
Gets the value of the node with validating its type against the provided type
nodeValue() - Method in class com.hazelcast.internal.yaml.YamlScalarImpl
 
nodeValue(Class<T>) - Method in class com.hazelcast.internal.yaml.YamlScalarImpl
 
NodeWideUsedCapacityCounter - Class in com.hazelcast.map.impl.mapstore.writebehind
Holds sum of all current write-behind-queue sizes(including backup partitions) of all maps on this node.
NodeWideUsedCapacityCounter(HazelcastProperties) - Constructor for class com.hazelcast.map.impl.mapstore.writebehind.NodeWideUsedCapacityCounter
 
NoLogFactory - Class in com.hazelcast.logging
 
NoLogFactory() - Constructor for class com.hazelcast.logging.NoLogFactory
 
noLogger() - Static method in class com.hazelcast.logging.Logger
 
NON_FRAGMENTED_SERVICE_NAMESPACE - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
NON_LOCAL_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
A MemberSelector instance that selects only remote members
none() - Static method in class com.hazelcast.client.impl.ClientSelectors
 
NONE - Static variable in class com.hazelcast.security.permission.InstancePermission
 
NonFragmentedServiceNamespace - Class in com.hazelcast.internal.partition
Internal ServiceNamespace implementation used by partitioning system to identify non-fragmented service structures.
NonSmartClientInvocationService - Class in com.hazelcast.client.impl.spi.impl
 
NonSmartClientInvocationService(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.impl.spi.impl.NonSmartClientInvocationService
 
NonSmartClientListenerService - Class in com.hazelcast.client.impl.spi.impl.listener
 
NonSmartClientListenerService(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.impl.spi.impl.listener.NonSmartClientListenerService
 
NonStopInvalidator - Class in com.hazelcast.internal.nearcache.impl.invalidation
Sends invalidations to Near Caches immediately.
NonStopInvalidator(String, Function<EventRegistration, Boolean>, NodeEngine) - Constructor for class com.hazelcast.internal.nearcache.impl.invalidation.NonStopInvalidator
 
NonTerminalJsonValue - Class in com.hazelcast.internal.json
This class is a placeholder for Json object/arrays that are not parsed by AbstractJsonGetter.
NonTerminalJsonValue() - Constructor for class com.hazelcast.internal.json.NonTerminalJsonValue
 
noop() - Static method in interface com.hazelcast.internal.util.function.ConsumerEx
Returns a consumer that does nothing.
NOOP_TENANT_CONTROL - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
NOOP_TENANT_CONTROL - Static variable in interface com.hazelcast.spi.tenantcontrol.TenantControl
Default no-op tenant control
NOOP_TENANT_CONTROL_FACTORY - Static variable in interface com.hazelcast.spi.tenantcontrol.TenantControlFactory
Default tenant control factory.
NoOpAuditlogService - Class in com.hazelcast.internal.auditlog.impl
 
NoOpAuditlogService.Builder - Class in com.hazelcast.internal.auditlog.impl
NoOpAuditlogService.NoOpEvent - Class in com.hazelcast.internal.auditlog.impl
 
NoOpClientEngine - Class in com.hazelcast.client.impl
 
NoOpClientEngine() - Constructor for class com.hazelcast.client.impl.NoOpClientEngine
 
NoOpCommand - Class in com.hazelcast.internal.ascii
 
NoOpCommand(byte[]) - Constructor for class com.hazelcast.internal.ascii.NoOpCommand
 
NoOpCommandProcessor - Class in com.hazelcast.internal.ascii
 
NoOpCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.NoOpCommandProcessor
 
NoOpHotRestartService - Class in com.hazelcast.internal.hotrestart
Empty implementation of HotRestartService to avoid null checks.
NoOpHotRestartService() - Constructor for class com.hazelcast.internal.hotrestart.NoOpHotRestartService
 
NoOpIdleStrategy - Class in com.hazelcast.internal.util.concurrent
Low-latency idle strategy to be employed in loops that do significant work on each iteration such that any work in the idle strategy would be wasteful.
NoOpIdleStrategy() - Constructor for class com.hazelcast.internal.util.concurrent.NoOpIdleStrategy
 
NoopInternalHotRestartService - Class in com.hazelcast.internal.hotrestart
Empty implementation of InternalHotRestartService to avoid null checks.
NoopInternalHotRestartService() - Constructor for class com.hazelcast.internal.hotrestart.NoopInternalHotRestartService
 
NoopTenantControl - Class in com.hazelcast.spi.impl.tenantcontrol
Default no-op implementation of TenantControl
NoopTenantControl() - Constructor for class com.hazelcast.spi.impl.tenantcontrol.NoopTenantControl
 
NoopTenantControlFactory - Class in com.hazelcast.spi.impl.tenantcontrol
Default implementation of TenantControlFactory, always returns a no-op tenant control
NoopTenantControlFactory() - Constructor for class com.hazelcast.spi.impl.tenantcontrol.NoopTenantControlFactory
 
NopCPMetadataStore - Class in com.hazelcast.cp.internal.persistence
Used when CP Subsystem works transiently (its state is not persisted).
NopCPPersistenceService - Class in com.hazelcast.cp.internal.persistence
Used when CP Subsystem works transiently (its state is not persisted).
NopCPPersistenceService() - Constructor for class com.hazelcast.cp.internal.persistence.NopCPPersistenceService
 
NopMigrationInterceptor() - Constructor for class com.hazelcast.internal.partition.impl.MigrationInterceptor.NopMigrationInterceptor
 
NopPartitionReplicaInterceptor - Class in com.hazelcast.internal.partition.impl
No-op partition replica interceptor which does nothing on partition change events.
NopPartitionReplicaInterceptor() - Constructor for class com.hazelcast.internal.partition.impl.NopPartitionReplicaInterceptor
 
NopRaftStateStore - Class in com.hazelcast.cp.internal.raft.impl.persistence
Used when a Raft node works transiently (its state is not persisted).
NORMAL_RESPONSE - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
normalFramesRead() - Method in class com.hazelcast.internal.networking.nio.NioInboundPipeline
 
normalize() - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
normalize(int, int) - Static method in class com.hazelcast.internal.util.QuickMath
Divide value by factor, take the smallest integer greater than or equal to the result, multiply that integer by factor, and return it.
normalize(long, int) - Static method in class com.hazelcast.internal.util.QuickMath
Divide value by factor, take the smallest integer greater than or equal to the result, multiply that integer by factor, and return it.
normalPacketsRead - Variable in class com.hazelcast.internal.networking.nio.InboundHandlerWithCounters
 
NormalResponse - Class in com.hazelcast.spi.impl.operationservice.impl.responses
A NormalResponse is send when an Operation needs to return a value.
NormalResponse() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.NormalResponse
 
NormalResponse(Object, long, int, boolean) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.NormalResponse
 
normalSize() - Method in interface com.hazelcast.spi.impl.operationexecutor.impl.OperationQueue
returns the number of normal operations pending.
normalSize() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationQueueImpl
 
NoSuchMessageTask - Class in com.hazelcast.client.impl.protocol.task
 
NoSuchMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
 
not(Predicate) - Static method in class com.hazelcast.query.Predicates
Creates a not predicate that will negate the result of the given predicate.
NOT_AVAILABLE - Static variable in interface com.hazelcast.map.impl.record.Record
 
NOT_CACHED - Static variable in interface com.hazelcast.internal.nearcache.NearCache
NOT_CACHED Object
NOT_CACHED - Static variable in interface com.hazelcast.map.impl.record.Record
If not a CachedDataRecord.
NOT_FOUND - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
 
NOT_LEADER_EXCEPTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
NOT_LOCKED - Static variable in class com.hazelcast.internal.util.LockGuard
 
NOT_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
NOT_RESERVED - Static variable in interface com.hazelcast.internal.nearcache.NearCacheRecord
 
NOT_SERIALIZABLE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
NOT_STORED - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
 
notActiveExceptionSupplier - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
notEqual(Comparable) - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
notEqual(Comparable) - Method in interface com.hazelcast.query.PredicateBuilder.EntryObject
 
notEqual(String, Comparable) - Static method in class com.hazelcast.query.Predicates
Creates a not equal predicate that will pass items if the given value and the value stored under the given item attribute are not equal.
NOTEQUAL_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
NotEqualPredicate - Class in com.hazelcast.query.impl.predicates
Not Equal Predicate
NotEqualPredicate() - Constructor for class com.hazelcast.query.impl.predicates.NotEqualPredicate
 
NotEqualPredicate(String, Comparable) - Constructor for class com.hazelcast.query.impl.predicates.NotEqualPredicate
 
notFinishedOperationsCount() - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
 
notFinishedOperationsCount() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
notFinishedOperationsCount() - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
notHaveAnyExpirableRecord(CachePartitionSegment) - Method in class com.hazelcast.cache.impl.eviction.CacheClearExpiredRecordsTask
 
notHaveAnyExpirableRecord(T) - Method in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
notHaveAnyExpirableRecord(PartitionContainer) - Method in class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
Here we check if that partition has any expirable record or not, if no expirable record exists in that partition no need to fire an expiration operation.
NotifiableEventListener<S> - Interface in com.hazelcast.internal.services
Contract point for event listeners to be notified by EventService.
Notifier - Interface in com.hazelcast.spi.impl.operationservice
A component used in wait/notify systems like Condition.
notify(RaftEndpoint, InternalCompletableFuture) - Method in class com.hazelcast.cp.internal.raft.impl.state.LeadershipTransferState
 
notify(Object) - Method in class com.hazelcast.spi.impl.SimpleExecutionCallback
 
NOTIFY_MAP_FLUSH - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
NOTIFY_TERM_CHANGE_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
notifyBackupComplete() - Method in class com.hazelcast.spi.impl.operationservice.impl.BaseInvocation
 
notifyBackupComplete(long) - Method in class com.hazelcast.spi.impl.operationservice.impl.InboundResponseHandler
 
notifyCloseListeners() - Method in class com.hazelcast.internal.networking.AbstractChannel
 
notifyExcludedMember(Address) - Method in interface com.hazelcast.internal.hotrestart.InternalHotRestartService
Notifies the excluded member and triggers the member force start process.
notifyExcludedMember(Address) - Method in class com.hazelcast.internal.hotrestart.NoopInternalHotRestartService
 
notifyFlush() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
notifyForRemovedMember(MemberImpl) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
NotifyMapFlushOperation - Class in com.hazelcast.map.impl.operation
Used to notify AwaitMapFlushOperation when StoreWorker managed to flush this flushSequence.
NotifyMapFlushOperation(String, long) - Constructor for class com.hazelcast.map.impl.operation.NotifyMapFlushOperation
 
NotifyMapFlushOperation() - Constructor for class com.hazelcast.map.impl.operation.NotifyMapFlushOperation
 
notifyResponse(Object, int) - Method in class com.hazelcast.spi.impl.operationservice.impl.BaseInvocation
 
notifyShutdownInitiated() - Method in class com.hazelcast.internal.util.executor.LoggingScheduledExecutor
 
NotifyTermChangeOp - Class in com.hazelcast.cp.internal.raftop
When leader of a Raft group changes, this operation is automatically committed to the Raft group so that related services can perform some actions.
NotifyTermChangeOp() - Constructor for class com.hazelcast.cp.internal.raftop.NotifyTermChangeOp
 
notifyThrowable(Throwable, int) - Method in class com.hazelcast.spi.impl.operationservice.impl.Invocation
 
notifyThrowable(Throwable, int) - Method in class com.hazelcast.spi.impl.operationservice.impl.RaftInvocation
 
notifyWaitKeys(CPGroupId, String, Collection<W>, Object) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
NotLeaderException - Exception in com.hazelcast.cp.exception
A CPSubsystemException which is thrown when a leader-only request is received by a non-leader member.
NotLeaderException(CPGroupId, RaftEndpoint, RaftEndpoint) - Constructor for exception com.hazelcast.cp.exception.NotLeaderException
 
NotPredicate - Class in com.hazelcast.query.impl.predicates
Not Predicate
NotPredicate(Predicate) - Constructor for class com.hazelcast.query.impl.predicates.NotPredicate
 
NotPredicate() - Constructor for class com.hazelcast.query.impl.predicates.NotPredicate
 
now - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
NULL - Static variable in class com.hazelcast.internal.json.Json
Represents the JSON literal null.
NULL - Static variable in class com.hazelcast.internal.json.JsonValue
Deprecated.
Use Json.NULL instead
NULL - Static variable in class com.hazelcast.query.impl.AbstractIndex
Represents a null-like value that is equal to itself and less than any other value except CompositeValue.NEGATIVE_INFINITY.
NULL_ADDRESS - Static variable in interface com.hazelcast.internal.memory.MemoryAllocator
The special value that does not correspond to an actual address and signals the absence of an address.
NULL_AGGREGATOR_IS_NOT_ALLOWED - Static variable in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
NULL_ARRAY_LENGTH - Static variable in class com.hazelcast.internal.nio.Bits
for null arrays, this value is written to the stream to represent null array size.
NULL_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
NULL_ENTRY_PROCESSOR_IS_NOT_ALLOWED - Static variable in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
NULL_EVICTOR - Static variable in interface com.hazelcast.map.impl.eviction.Evictor
 
NULL_FRAME - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
NULL_GETTER - Static variable in class com.hazelcast.query.impl.getters.NullGetter
Shared singleton instance of this class.
NULL_KEY_IS_NOT_ALLOWED - Static variable in class com.hazelcast.cache.impl.CacheProxyUtil
 
NULL_KEY_IS_NOT_ALLOWED - Static variable in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
NULL_KEY_IS_NOT_ALLOWED - Static variable in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
NULL_KEY_IS_NOT_ALLOWED - Static variable in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
NULL_LISTENER_IS_NOT_ALLOWED - Static variable in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
NULL_LISTENER_IS_NOT_ALLOWED - Static variable in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
NULL_LISTENER_IS_NOT_ALLOWED - Static variable in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
NULL_MAX_IDLE_UNIT_IS_NOT_ALLOWED - Static variable in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
NULL_MULTIVALUE_GETTER - Static variable in class com.hazelcast.query.impl.getters.NullMultiValueGetter
Shared singleton instance of this class.
NULL_OBJECT - Static variable in class com.hazelcast.internal.util.Memoizer
Null object to be kept as values which are null
NULL_OBJECT - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
NULL_POINTER - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
NULL_PREDICATE_IS_NOT_ALLOWED - Static variable in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
NULL_PROJECTION_IS_NOT_ALLOWED - Static variable in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
NULL_QUERY_CACHE - Static variable in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
Null query cache implementation.
NULL_TIMEUNIT_IS_NOT_ALLOWED - Static variable in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
NULL_TTL_UNIT_IS_NOT_ALLOWED - Static variable in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
NULL_VALUE_IS_NOT_ALLOWED - Static variable in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
NULL_VALUE_IS_NOT_ALLOWED - Static variable in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
NULL_VALUE_IS_NOT_ALLOWED - Static variable in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
NullGetter - Class in com.hazelcast.query.impl.getters
Null getter describes neutral behaviour for a Getter.
NullMultiValueGetter - Class in com.hazelcast.query.impl.getters
NullMultiValue getter describes neutral behaviour for a Getter.
NullQueryCache - Class in com.hazelcast.map.impl.querycache.subscriber
Object for neutral InternalQueryCache implementation.
NullSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.NullSerializer
 
nullSerializerAdapter - Variable in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
nullsFirst(Comparator<? super T>) - Static method in interface com.hazelcast.internal.util.function.ComparatorEx
nullsFirst(ComparatorEx<? super T>) - Static method in interface com.hazelcast.internal.util.function.ComparatorEx
nullsLast(Comparator<? super T>) - Static method in interface com.hazelcast.internal.util.function.ComparatorEx
nullsLast(ComparatorEx<? super T>) - Static method in interface com.hazelcast.internal.util.function.ComparatorEx
nullToEmpty(Collection<T>) - Static method in class com.hazelcast.internal.util.CollectionUtil
Returns an empty Collection if argument is null.
nullToEmpty(Iterable<T>) - Static method in class com.hazelcast.internal.util.IterableUtil
Return empty Iterable if argument is null
NUMBER_AVG - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
NUMBER_OF_INTEGER_FIELD_TYPES - Static variable in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
NUMBER_OF_LONG_FIELD_TYPES - Static variable in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
NumberAverageAggregator<I> - Class in com.hazelcast.aggregation.impl
 
NumberAverageAggregator() - Constructor for class com.hazelcast.aggregation.impl.NumberAverageAggregator
 
NumberAverageAggregator(String) - Constructor for class com.hazelcast.aggregation.impl.NumberAverageAggregator
 
numberAvg() - Static method in class com.hazelcast.aggregation.Aggregators
 
numberAvg(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
numberOfEntries - Variable in class com.hazelcast.map.impl.event.MapEventData
 
Numbers - Class in com.hazelcast.query.impl
Provides utilities which compare and canonicalize Number instances.

O

OAHashSet<E> - Class in com.hazelcast.internal.util.collection
Not thread-safe open-addressing hash Set implementation with linear probing for CPU cache efficiency.
OAHashSet() - Constructor for class com.hazelcast.internal.util.collection.OAHashSet
Constructs an OAHashSet instance with default initial capacity and default load factor
OAHashSet(int) - Constructor for class com.hazelcast.internal.util.collection.OAHashSet
Constructs an OAHashSet instance with the specified initial capacity and with the default load factor
OAHashSet(int, float) - Constructor for class com.hazelcast.internal.util.collection.OAHashSet
Constructs an OAHashSet instance with the specified initial capacity and load factor
object() - Static method in class com.hazelcast.internal.json.Json
Creates a new empty JsonObject.
OBJECT_REFERENCE_ALIGN - Static variable in class com.hazelcast.internal.memory.impl.AlignmentUtil
 
OBJECT_REFERENCE_MASK - Static variable in class com.hazelcast.internal.memory.impl.AlignmentUtil
 
ObjectDataInput - Interface in com.hazelcast.nio
Provides serialization methods for arrays of primitive types.
ObjectDataInputStream - Class in com.hazelcast.internal.serialization.impl
 
ObjectDataInputStream(InputStream, InternalSerializationService) - Constructor for class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
ObjectDataOutput - Interface in com.hazelcast.nio
Provides serialization methods for arrays by extending DataOutput
ObjectDataOutputStream - Class in com.hazelcast.internal.serialization.impl
 
ObjectDataOutputStream(OutputStream, InternalSerializationService) - Constructor for class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
objectFieldOffset(Field) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Gets the offset of given field.
objectFieldOffset(Field) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
objectFieldOffset(Field) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
ObjectMultiMapProxy<K,V> - Class in com.hazelcast.multimap.impl
 
ObjectMultiMapProxy(MultiMapConfig, MultiMapService, NodeEngine, String) - Constructor for class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
objectName - Variable in class com.hazelcast.client.impl.protocol.codec.CPGroupDestroyCPObjectCodec.RequestParameters
The name of this distributed object
objectName - Variable in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
objectNamespace - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
ObjectNamespace - Interface in com.hazelcast.internal.services
An ObjectNamespace that makes identification of object within a service possible.
objectNamespace - Variable in class com.hazelcast.map.impl.MapContainer
 
ObjectQueryCacheRecordFactory - Class in com.hazelcast.map.impl.querycache.subscriber.record
Factory for ObjectQueryCacheRecord.
ObjectQueryCacheRecordFactory(SerializationService) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.record.ObjectQueryCacheRecordFactory
 
ObjectRecordFactory - Class in com.hazelcast.map.impl.record
 
ObjectRecordFactory(MapConfig, SerializationService) - Constructor for class com.hazelcast.map.impl.record.ObjectRecordFactory
 
ObjectReplicatedRecordStorage<K,V> - Class in com.hazelcast.replicatedmap.impl.record
This is a InMemoryFormat.OBJECT based ReplicatedRecordStore implementation
ObjectReplicatedRecordStorage(String, ReplicatedMapService, int) - Constructor for class com.hazelcast.replicatedmap.impl.record.ObjectReplicatedRecordStorage
 
objectToDataCollection(Collection<C>, SerializationService) - Static method in class com.hazelcast.internal.util.CollectionUtil
Converts a collection of any type to a collection of Data.
objectToDataCollection(Collection<C>, Collection<Data>, SerializationService, String) - Static method in class com.hazelcast.internal.util.CollectionUtil
Converts a collection of any type to a collection of Data.
obtainContextFor(Indexes) - Method in class com.hazelcast.query.impl.GlobalQueryContextProvider
 
obtainContextFor(Indexes) - Method in class com.hazelcast.query.impl.GlobalQueryContextProviderWithStats
 
obtainContextFor(Indexes) - Method in class com.hazelcast.query.impl.PartitionQueryContextProvider
 
obtainContextFor(Indexes) - Method in class com.hazelcast.query.impl.PartitionQueryContextProviderWithStats
 
obtainContextFor(Indexes) - Method in interface com.hazelcast.query.impl.QueryContextProvider
Obtains a query context for the given indexes.
obtrudeException(Throwable) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
obtrudeException(Throwable) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
obtrudeException(Throwable) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
obtrudeValue(V) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
obtrudeValue(V) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
obtrudeValue(V) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
occurrenceSet - Variable in class com.hazelcast.config.AbstractDomConfigProcessor
Set collecting already seen elements.
of(CacheConfig) - Static method in class com.hazelcast.cache.impl.PreJoinCacheConfig
 
of(CacheConfig<K, V>, SerializationService) - Static method in class com.hazelcast.client.impl.protocol.codec.holder.CacheConfigHolder
 
of(EvictionConfig, SerializationService) - Static method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.EvictionConfigHolder
 
of(ListenerConfig, SerializationService) - Static method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.ListenerConfigHolder
 
of(MapStoreConfig, SerializationService) - Static method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
of(NearCacheConfig, SerializationService) - Static method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.NearCacheConfigHolder
 
of(PredicateConfig, SerializationService) - Static method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.PredicateConfigHolder
 
of(QueryCacheConfig, SerializationService) - Static method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
of(QueueStoreConfig, SerializationService) - Static method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueueStoreConfigHolder
 
of(RingbufferStoreConfig, SerializationService) - Static method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.RingbufferStoreConfigHolder
 
of(String) - Static method in enum com.hazelcast.internal.cluster.fd.ClusterFailureDetectorType
Returns the ClusterFailureDetectorType identified by the given name or throws an IllegalArgumentException if none can be identified.
of(X, Y) - Static method in class com.hazelcast.internal.util.BiTuple
 
of(T) - Static method in class com.hazelcast.internal.util.StateMachine
 
of(X, Y, Z) - Static method in class com.hazelcast.internal.util.TriTuple
 
of() - Static method in class com.hazelcast.map.impl.query.Query
 
of(Query) - Static method in class com.hazelcast.map.impl.query.Query
 
of(Address, String, String) - Static method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
 
of(int, String, String) - Static method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
 
of(String) - Static method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
 
of(String) - Static method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Reconstructs a ScheduledTaskHandler from a URN String.
of(int, int, int) - Static method in class com.hazelcast.version.MemberVersion
 
of(String) - Static method in class com.hazelcast.version.MemberVersion
 
of(int, int) - Static method in class com.hazelcast.version.Version
 
of(String) - Static method in class com.hazelcast.version.Version
Parse the given string to a Version.
offer(E) - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
It is advised to use this method in a try-catch block to take the offer operation full lifecycle control, in a "lost node" scenario you can not be sure offer is succeeded or not so you may want to retry.
offer(E, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
offer(E) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnQueueProxy
 
offer(E, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnQueueProxy
 
offer(E) - Method in interface com.hazelcast.collection.BaseQueue
Inserts the specified element into this queue if it is possible to do so immediately without violating capacity restrictions.
offer(E, long, TimeUnit) - Method in interface com.hazelcast.collection.BaseQueue
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available.
offer(Data) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
 
OFFER - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
offer(E) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
offer(E, long, TimeUnit) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
offer(E) - Method in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxy
 
offer(E, long, TimeUnit) - Method in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxy
 
offer(String, Object) - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
offer(String, Object) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
offer(T) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationQueue
 
offer(int, E) - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Offers an item to the queue at the given index.
offer(Queue<E>, E) - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Offers an item to the given queue.
offer(E) - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyorSingleQueue
Offers an item to the queue.
offer(E) - Method in class com.hazelcast.internal.util.concurrent.ManyToOneConcurrentArrayQueue
 
offer(E) - Method in class com.hazelcast.internal.util.concurrent.MPSCQueue
 
offer(E, long, TimeUnit) - Method in class com.hazelcast.internal.util.concurrent.MPSCQueue
 
offer(E) - Method in class com.hazelcast.internal.util.concurrent.OneToOneConcurrentArrayQueue
 
offer(E) - Method in interface com.hazelcast.transaction.TransactionalQueue
Inserts the specified element into this queue if it is possible to do so immediately without violating capacity restrictions.
offer(E, long, TimeUnit) - Method in interface com.hazelcast.transaction.TransactionalQueue
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available.
OFFER_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
offerBackup(Data, long) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Offers the item to the backup map.
OfferBackupOperation - Class in com.hazelcast.collection.impl.queue.operations
Backup items during offer operation.
OfferBackupOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.OfferBackupOperation
 
OfferBackupOperation(String, Data, long) - Constructor for class com.hazelcast.collection.impl.queue.operations.OfferBackupOperation
 
OfferOperation - Class in com.hazelcast.collection.impl.queue.operations
Contains offer operation for the Queue.
OfferOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.OfferOperation
 
OfferOperation(String, long, Data) - Constructor for class com.hazelcast.collection.impl.queue.operations.OfferOperation
 
Offload - Class in com.hazelcast.spi.impl.operationservice
This is an internal class.
Offload(Operation) - Constructor for class com.hazelcast.spi.impl.operationservice.Offload
Creates a new Offload instance.
OFFLOAD_ORDINAL - Static variable in class com.hazelcast.spi.impl.operationservice.CallStatus
The ordinal value for an Offload.
Offloadable - Interface in com.hazelcast.core
Allows off-loading the processing unit implementing this interface to the specified or default Executor.
OFFLOADABLE_EXECUTOR - Static variable in interface com.hazelcast.core.Offloadable
Constant meaning that processing will be off-loaded to the default OFFLOADABLE_EXECUTOR executor.
OFFLOADABLE_EXECUTOR - Static variable in interface com.hazelcast.spi.impl.executionservice.ExecutionService
Name of the offloadable executor.
offloadedOperation() - Method in class com.hazelcast.spi.impl.operationservice.Offload
Returns the Operation that created this Offload.
offprintHandler(String) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
offprintHandler(String) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorMemberOwnedContainer
 
offset - Variable in class com.hazelcast.internal.json.Location
The absolute character index, starting at 0.
OFFSET_BACKUP_ACKS - Static variable in class com.hazelcast.spi.impl.operationservice.impl.responses.NormalResponse
 
OFFSET_CALL_ID - Static variable in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
 
OFFSET_DATA_LENGTH - Static variable in class com.hazelcast.spi.impl.operationservice.impl.responses.NormalResponse
 
OFFSET_DATA_PAYLOAD - Static variable in class com.hazelcast.spi.impl.operationservice.impl.responses.NormalResponse
 
OFFSET_IDENTIFIED - Static variable in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
 
OFFSET_IS_DATA - Static variable in class com.hazelcast.spi.impl.operationservice.impl.responses.NormalResponse
 
OFFSET_NOT_DATA - Static variable in class com.hazelcast.spi.impl.operationservice.impl.responses.NormalResponse
 
OFFSET_SERIALIZER_TYPE_ID - Static variable in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
 
OFFSET_TYPE_FACTORY_ID - Static variable in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
 
OFFSET_TYPE_ID - Static variable in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
 
OFFSET_URGENT - Static variable in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
 
offsetOfUnassignedSentinel - Variable in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
Offset (from the slot's base address) where the unassigned sentinel value is to be found.
oldestSequence(ObjectNamespace, int) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
 
oldestSequence - Variable in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalSubscribeCodec.ResponseParameters
TODO DOC
oldestSequence - Variable in class com.hazelcast.client.impl.protocol.codec.MapEventJournalSubscribeCodec.ResponseParameters
TODO DOC
oldestSequence(ObjectNamespace, int) - Method in interface com.hazelcast.internal.journal.EventJournal
Returns the sequence of the oldest event stored in the event journal.
oldestSequence(ObjectNamespace, int) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
 
oldValue - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefCompareAndSetCodec.RequestParameters
The expected value
oldValue - Variable in class com.hazelcast.client.impl.protocol.codec.CacheReplaceCodec.RequestParameters
Old value to match if exists before removing.
oldValue - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceIfSameCodec.RequestParameters
Replace the key value if it is the old value.
oldValue - Variable in class com.hazelcast.core.EntryEvent
 
oldValue - Variable in class com.hazelcast.map.impl.operation.BasePutOperation
 
oldValue - Variable in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
 
ON_JOIN_REGISTRATION - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
onAccept(Socket) - Method in interface com.hazelcast.nio.MemberSocketInterceptor
This method will be called when a connection to a member node is accepted meaning security requirements and clusters are matching.
onAccess(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
onAccess(long) - Method in interface com.hazelcast.map.impl.record.Record
 
onAccessSafe(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
onAccessSafe(long) - Method in interface com.hazelcast.map.impl.record.Record
An implementation must be thread safe if the record might be accessed from multiple threads.
onAccumulationFinished() - Method in class com.hazelcast.aggregation.Aggregator
Called after the last call to combine on a specific instance.
onAfterRun() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskStatisticsImpl
 
onAfterRun() - Method in interface com.hazelcast.scheduledexecutor.impl.TaskLifecycleListener
 
onBeforeLock(String, T) - Method in interface com.hazelcast.internal.services.LockInterceptorService
 
onBeforeLock(String, Data) - Method in class com.hazelcast.map.impl.MapService
 
onBeforeLock(String, Data) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
onBeforeRun() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskStatisticsImpl
 
onBeforeRun() - Method in interface com.hazelcast.scheduledexecutor.impl.TaskLifecycleListener
 
onChange(SplitBrainProtectionEvent) - Method in interface com.hazelcast.splitbrainprotection.SplitBrainProtectionListener
Called when the state of the split brain detector is changed.
onClear() - Method in class com.hazelcast.map.impl.recordstore.EventJournalWriterRecordStoreMutationObserver
 
onClear() - Method in class com.hazelcast.map.impl.recordstore.JsonMetadataRecordStoreMutationObserver
 
onClear() - Method in interface com.hazelcast.map.impl.recordstore.RecordStoreMutationObserver
Called if the observed RecordStore is cleared
onClear() - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
onClear() - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
onClear() - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Invoked by the associated index after the index was cleared.
onClientAcquiredResource(UUID) - Method in interface com.hazelcast.client.impl.ClientEngine
Notify client engine that a client with given uuid required a resource (lock) on this member
onClientAcquiredResource(UUID) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
onClientAcquiredResource(UUID) - Method in class com.hazelcast.client.impl.NoOpClientEngine
 
onClientDisconnected(UUID) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
onClientDisconnected(UUID) - Method in class com.hazelcast.spi.impl.operationparker.impl.OperationParkerImpl
 
onClose(Channel) - Method in interface com.hazelcast.internal.networking.ChannelCloseListener
Called when the channel is closed.
onClusterConnect(Connection) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
onClusterConnect() - Method in class com.hazelcast.client.impl.connection.ClientConnectionStrategy
If a cluster connection is established, this method will be called.
onClusterConnect() - Method in class com.hazelcast.client.impl.connection.nio.DefaultClientConnectionStrategy
 
onClusterDisconnect() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
onClusterStateChange(ClusterState) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
onClusterStateChange(ClusterState, boolean) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
onClusterStateChange(ClusterState, boolean) - Method in interface com.hazelcast.instance.impl.NodeExtension
Called during the commit phase of the cluster state change transaction, just after updating the value of the cluster state on the local member, while still holding the cluster lock.
onClusterStateChange(ClusterState) - Method in interface com.hazelcast.internal.cluster.ClusterStateListener
Called when cluster state is changed
onClusterStateChange(ClusterState) - Method in class com.hazelcast.internal.eviction.ExpirationManager
 
onClusterStateChange(ClusterState) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
onClusterStateChange(ClusterState) - Method in class com.hazelcast.map.impl.MapService
 
onClusterStateChange(ClusterState) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
onClusterVersionChange(Version) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
onClusterVersionChange(Version) - Method in interface com.hazelcast.instance.impl.NodeExtension
Called after cluster version is changed.
onClusterVersionChange(Version) - Method in interface com.hazelcast.internal.cluster.ClusterVersionListener
Invoked on registered listeners after the new cluster version has been applied.
onClusterVersionChange(Version) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
onCombinationFinished() - Method in class com.hazelcast.aggregation.Aggregator
Called after the last call to combine on a specific instance.
onCombineFinished() - Method in class com.hazelcast.map.impl.query.AggregationResult
 
onCombineFinished() - Method in class com.hazelcast.map.impl.query.QueryResult
 
onCombineFinished() - Method in interface com.hazelcast.map.impl.query.Result
Invoked when the result combining phase is finished.
onComplete() - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
onComplete(Map<Member, Object>) - Method in interface com.hazelcast.core.MultiExecutionCallback
Called after all executions are completed.
onComplete(long) - Method in class com.hazelcast.internal.partition.MigrationStateImpl
 
onComplete(int, long) - Method in class com.hazelcast.internal.partition.MigrationStateImpl
 
onComplete() - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
onCompletionAsyncOperation(Operation) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
onCompletionAsyncOperation(Operation) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Should be called when the asynchronous operation has completed.
onConfigRegistered(MapConfig) - Method in interface com.hazelcast.internal.dynamicconfig.DynamicConfigListener
Called when a new MapConfig object is created locally.
onConfigRegistered(CacheSimpleConfig) - Method in interface com.hazelcast.internal.dynamicconfig.DynamicConfigListener
Called when a new CacheSimpleConfig object is created locally.
onConfigRegistered(MapConfig) - Method in class com.hazelcast.internal.dynamicconfig.EmptyDynamicConfigListener
 
onConfigRegistered(CacheSimpleConfig) - Method in class com.hazelcast.internal.dynamicconfig.EmptyDynamicConfigListener
 
onConnect(ClientConnection) - Method in class com.hazelcast.client.impl.connection.ClientConnectionStrategy
If the ClientConnectionManager opens a new connection to a member, this method will be called with the connection parameter
onConnect(ClientConnection) - Method in class com.hazelcast.client.impl.connection.nio.DefaultClientConnectionStrategy
 
onConnect(Socket) - Method in interface com.hazelcast.nio.SocketInterceptor
Called when a connection is established.
onConnectionClose(T, Throwable, boolean) - Method in interface com.hazelcast.internal.nio.ConnectionLifecycleListener
Deals with cleaning up a closed connection.
onConnectionClose(TcpIpConnection, Throwable, boolean) - Method in class com.hazelcast.internal.nio.tcp.TcpIpEndpointManager.EndpointConnectionLifecycleListener
 
onCPSubsystemRestart() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockService
 
onCPSubsystemRestart() - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueService
 
onCPSubsystemRestart() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
onCPSubsystemRestart() - Method in interface com.hazelcast.cp.internal.datastructures.spi.RaftManagedService
Called when CP Subsystem is restarted.
onCPSubsystemRestart() - Method in class com.hazelcast.cp.internal.session.ProxySessionManagerService
 
onCreate(Data, Object, ExpiryPolicy, long, boolean, int, boolean) - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
onCreateRecordError(Data, Object, long, long, boolean, int, UUID, R, Throwable) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
onDeleteRecord(Data, R, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
OnDemandIndexStats - Class in com.hazelcast.monitor.impl
Holds the intermediate results while combining the partitioned index stats to produce the final per-index stats.
OnDemandIndexStats() - Constructor for class com.hazelcast.monitor.impl.OnDemandIndexStats
 
onDeregister(CacheService, String, String, EventRegistration) - Method in class com.hazelcast.cache.impl.CacheEventListenerAdaptor
 
onDeregister(S, String, String, EventRegistration) - Method in interface com.hazelcast.internal.services.NotifiableEventListener
Called when this listener deregistered from EventService.
onDeregister(Object, String, String, EventRegistration) - Method in class com.hazelcast.map.impl.MapService
 
onDestroy() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
onDestroy() - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
onDestroy() - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
onDestroy() - Method in class com.hazelcast.client.cp.internal.datastructures.countdownlatch.CountDownLatchProxy
 
onDestroy() - Method in class com.hazelcast.client.cp.internal.datastructures.lock.FencedLockProxy
 
onDestroy() - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionAwareSemaphoreProxy
 
onDestroy() - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionlessSemaphoreProxy
 
onDestroy() - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
onDestroy() - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
onDestroy() - Method in class com.hazelcast.client.impl.spi.ClientProxy
Called before proxy is destroyed.
onDestroy() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
onDestroy() - Method in class com.hazelcast.collection.impl.list.ListContainer
 
onDestroy() - Method in class com.hazelcast.collection.impl.set.SetContainer
 
onDestroy() - Method in class com.hazelcast.map.impl.MapContainer
 
onDestroy(String) - Method in class com.hazelcast.map.impl.MapSplitBrainProtectionAwareService
 
onDestroy(boolean) - Method in class com.hazelcast.map.impl.recordstore.EventJournalWriterRecordStoreMutationObserver
 
onDestroy(boolean) - Method in class com.hazelcast.map.impl.recordstore.JsonMetadataRecordStoreMutationObserver
 
onDestroy(boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStoreMutationObserver
Called when the observed RecordStore is being destroyed.
onDestroy() - Method in class com.hazelcast.spi.impl.merge.AbstractContainerCollector
onDetected() - Method in class com.hazelcast.internal.util.ConcurrencyDetection
Called when concurrency is detected.
onDisconnect(ClientConnection) - Method in class com.hazelcast.client.impl.connection.ClientConnectionStrategy
If a connection is disconnected, this method will be called with the connection parameter
onDisconnect(ClientConnection) - Method in class com.hazelcast.client.impl.connection.nio.DefaultClientConnectionStrategy
 
onDisconnect(Address, Throwable) - Method in interface com.hazelcast.internal.nio.IOService
 
onDisconnect(Address, Throwable) - Method in class com.hazelcast.internal.nio.NodeIOService
 
onDisconnectFromCluster() - Method in class com.hazelcast.client.impl.connection.ClientConnectionStrategy
If the cluster connection is lost for any reason, this method will be called.
onDisconnectFromCluster() - Method in class com.hazelcast.client.impl.connection.nio.DefaultClientConnectionStrategy
 
ONE_HUNDRED - Static variable in class com.hazelcast.map.impl.eviction.EvictionChecker
 
onEncryptionKeyChange(byte[]) - Method in interface com.hazelcast.spi.impl.securestore.SecureStore.EncryptionKeyListener
Called when the encryption key in the Secure Store changes.
onEndpointLeft(Address) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
onEndpointLeft(Address) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Cleans up heartbeats and fails invocations for the given endpoint.
onEntryAdded(Object, Object) - Method in class com.hazelcast.monitor.impl.GlobalIndexOperationStats
 
onEntryAdded(Object, Object) - Method in interface com.hazelcast.monitor.impl.IndexOperationStats
Invoked by the associated index on every entry addition.
onEntryAdded(Object, Object) - Method in class com.hazelcast.monitor.impl.PartitionIndexOperationStats
 
onEntryEvent(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
This method is called when an one of the methods of the EntryListener is not overridden.
onEntryEvent(EntryEvent<K, V>) - Method in class com.hazelcast.map.impl.MapListenerAdapter
This method is called when an one of the methods of the EntryListener is not overridden.
onEntryRemoved(Object) - Method in class com.hazelcast.monitor.impl.GlobalIndexOperationStats
 
onEntryRemoved(Object) - Method in interface com.hazelcast.monitor.impl.IndexOperationStats
Invoked by the associated index on every entry removal.
onEntryRemoved(Object) - Method in class com.hazelcast.monitor.impl.PartitionIndexOperationStats
 
onePhase - Variable in class com.hazelcast.client.impl.protocol.codec.XATransactionCommitCodec.RequestParameters
If true, the prepare is also done.
onError(Channel, Throwable) - Method in interface com.hazelcast.internal.networking.ChannelErrorHandler
Called when an error was detected.
onError(Throwable) - Method in class com.hazelcast.internal.networking.nio.NioPipeline
Is called when the NioPipeline.process() throws a Throwable.
onError(Channel, Throwable) - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnectionChannelErrorHandler
 
onError(Throwable) - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnectionErrorHandler
 
OneToOneConcurrentArrayQueue<E> - Class in com.hazelcast.internal.util.concurrent
Single producer to single consumer concurrent queue backed by an array.
OneToOneConcurrentArrayQueue(int) - Constructor for class com.hazelcast.internal.util.concurrent.OneToOneConcurrentArrayQueue
 
onEvent(IMapEvent) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddListenerMessageTask
 
onEvent(T) - Method in interface com.hazelcast.internal.partition.PartitionEventListener
 
onEvent(IMapEvent) - Method in class com.hazelcast.map.impl.InternalMapListenerAdapter
 
onEvent(T) - Method in interface com.hazelcast.map.impl.ListenerAdapter
Handle event.
onEvent(IMapEvent) - Method in class com.hazelcast.map.impl.querycache.subscriber.SubscriberListener
 
onEventLogged(Event) - Method in interface com.hazelcast.internal.management.ManagementCenterEventListener
Callback for logging MC events.
onEvict(Data, R, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
onEvict(A, E, boolean) - Method in interface com.hazelcast.internal.eviction.EvictionListener
Called when an Evictable entry is evicted.
onEvict(KS, R, boolean) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
onEvict(K, R, boolean) - Method in class com.hazelcast.internal.nearcache.impl.store.BaseHeapNearCacheRecordStore
 
onEvictRecord(Data, Record) - Method in class com.hazelcast.map.impl.recordstore.EventJournalWriterRecordStoreMutationObserver
 
onEvictRecord(Data, Record) - Method in class com.hazelcast.map.impl.recordstore.JsonMetadataRecordStoreMutationObserver
 
onEvictRecord(Data, R) - Method in interface com.hazelcast.map.impl.recordstore.RecordStoreMutationObserver
Called when a record is evicted from the observed RecordStore
onException(Throwable) - Method in class com.hazelcast.spi.impl.operationservice.impl.RaftInvocation
 
onExecutionFailure(Throwable) - Method in class com.hazelcast.cache.impl.operation.CacheClearExpiredOperation
 
onExecutionFailure(Throwable) - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
Deprecated.
 
onExecutionFailure(Throwable) - Method in class com.hazelcast.internal.cluster.impl.operations.OnJoinOp
 
onExecutionFailure(Throwable) - Method in class com.hazelcast.internal.partition.operation.MigrationOperation
Called when an Exception/Error is thrown during operation execution.
onExecutionFailure(Throwable) - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncResponse
 
onExecutionFailure(Throwable) - Method in class com.hazelcast.map.impl.operation.EntryOperation
 
onExecutionFailure(Throwable) - Method in class com.hazelcast.map.impl.operation.MapClearExpiredOperation
 
onExecutionFailure(Throwable) - Method in class com.hazelcast.map.impl.operation.MapOperation
 
onExecutionFailure(Throwable) - Method in class com.hazelcast.map.impl.operation.MapReplicationOperation
 
onExecutionFailure(Throwable) - Method in class com.hazelcast.map.impl.query.QueryOperation
 
onExecutionFailure(Throwable) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
 
onExecutionFailure(Throwable) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation
 
onExecutionFailure(Throwable) - Method in class com.hazelcast.spi.impl.operationservice.Operation
Called when an Exception/Error is thrown during operation execution.
onExpire(K, R) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
onFailedConnection(Address) - Method in interface com.hazelcast.internal.nio.IOService
 
onFailedConnection(Address) - Method in class com.hazelcast.internal.nio.NodeIOService
 
onFailure(Throwable) - Method in interface com.hazelcast.core.ExecutionCallback
Called when an execution is completed with an error.
onFailure(Throwable) - Method in class com.hazelcast.spi.impl.SimpleExecutionCallback
 
onFatalError(Exception) - Method in interface com.hazelcast.internal.nio.IOService
 
onFatalError(Exception) - Method in class com.hazelcast.internal.nio.NodeIOService
 
onFinishDeserialization() - Static method in class com.hazelcast.internal.usercodedeployment.impl.ClassLocator
 
onFinishDeserialization() - Static method in class com.hazelcast.internal.usercodedeployment.impl.ThreadLocalClassCache
 
onGet(Data, ExpiryPolicy, Object, R) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
onGet(K, V, R) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
onGetAndRemoveAsyncInternal(K, Data, ClientDelegatingFuture<T>, BiConsumer<T, Throwable>) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
onGetError(Data, ExpiryPolicy, Object, R, Throwable) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
onGetError(K, V, R, Throwable) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
onHeartbeat(MemberImpl, long) - Method in class com.hazelcast.internal.cluster.impl.ClusterHeartbeatManager
Accepts the heartbeat message from member created at timestamp.
onHeartbeat(Member, long) - Method in interface com.hazelcast.splitbrainprotection.HeartbeatAware
Notifies of a received heartbeat.
onHeartbeat(Member, long) - Method in class com.hazelcast.splitbrainprotection.impl.ProbabilisticSplitBrainProtectionFunction
 
onHeartbeat(Member, long) - Method in class com.hazelcast.splitbrainprotection.impl.RecentlyActiveSplitBrainProtectionFunction
 
onHeartbeat(Member, long) - Method in class com.hazelcast.splitbrainprotection.impl.SplitBrainProtectionServiceImpl
 
onIndexHit(long, long) - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
onIndexHit(long, long) - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
onIndexHit(long, long) - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Invoked by the associated index after every index hit.
onInit() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskStatisticsImpl
 
onInit() - Method in interface com.hazelcast.scheduledexecutor.impl.TaskLifecycleListener
 
onInitialClusterState(ClusterState) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
onInitialClusterState(ClusterState) - Method in interface com.hazelcast.instance.impl.NodeExtension
Called when initial cluster state is received while joining the cluster.
onInitialize() - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
onInitialize() - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
onInitialize() - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
onInitialize() - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
onInitialize() - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
onInitialize() - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
onInitialize() - Method in class com.hazelcast.client.impl.proxy.ClientRingbufferProxy
 
onInitialize() - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
onInitialize() - Method in class com.hazelcast.client.impl.spi.ClientProxy
Called when proxy is created.
onInitialize() - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
onInsert(long, IndexOperationStats, Index.OperationSource) - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
onInsert(long, IndexOperationStats, Index.OperationSource) - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
onInsert(long, IndexOperationStats, Index.OperationSource) - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Invoked by the associated index after every insert operation.
onInterruptDetected() - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
onInterruptDetected() - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
onInterruptDetected() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationFuture
 
onInvalidate(Invalidation) - Method in interface com.hazelcast.map.impl.nearcache.invalidation.InvalidationListener
Called upon an invalidation.
onInvocationException(Throwable) - Method in class com.hazelcast.cache.impl.operation.CacheExpireBatchBackupOperation
 
onInvocationException(Throwable) - Method in class com.hazelcast.cache.impl.operation.CacheOperation
 
onInvocationException(Throwable) - Method in class com.hazelcast.cp.internal.operation.GetLeadedGroupsOp
 
onInvocationException(Throwable) - Method in class com.hazelcast.cp.internal.operation.TransferLeadershipOp
 
onInvocationException(Throwable) - Method in class com.hazelcast.executor.impl.operations.MemberCallableTaskOperation
 
onInvocationException(Throwable) - Method in class com.hazelcast.internal.cluster.impl.operations.CommitClusterStateOp
 
onInvocationException(Throwable) - Method in class com.hazelcast.internal.cluster.impl.operations.FetchMembersViewOp
 
onInvocationException(Throwable) - Method in class com.hazelcast.internal.cluster.impl.operations.LockClusterStateOp
 
onInvocationException(Throwable) - Method in class com.hazelcast.internal.cluster.impl.operations.RollbackClusterStateOp
 
onInvocationException(Throwable) - Method in class com.hazelcast.internal.dynamicconfig.AddDynamicConfigOperation
 
onInvocationException(Throwable) - Method in class com.hazelcast.internal.partition.operation.AssignPartitions
 
onInvocationException(Throwable) - Method in class com.hazelcast.internal.partition.operation.FetchPartitionStateOperation
 
onInvocationException(Throwable) - Method in class com.hazelcast.internal.partition.operation.HasOngoingMigration
 
onInvocationException(Throwable) - Method in class com.hazelcast.internal.partition.operation.MigrationCommitOperation
 
onInvocationException(Throwable) - Method in class com.hazelcast.internal.partition.operation.MigrationRequestOperation
 
onInvocationException(Throwable) - Method in class com.hazelcast.internal.partition.operation.PromotionCommitOperation
 
onInvocationException(Throwable) - Method in class com.hazelcast.internal.partition.operation.PublishCompletedMigrationsOperation
 
onInvocationException(Throwable) - Method in class com.hazelcast.map.impl.operation.EvictBatchBackupOperation
 
onInvocationException(Throwable) - Method in class com.hazelcast.map.impl.query.QueryOperation
 
onInvocationException(Throwable) - Method in class com.hazelcast.spi.impl.operationservice.Operation
Called when an Exception/Error is thrown during an invocation.
onInvocationException(Throwable) - Method in class com.hazelcast.transaction.impl.operations.BroadcastTxRollbackOperation
 
onInvocationException(Throwable) - Method in class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
 
onInvocationException(Throwable) - Method in class com.hazelcast.transaction.impl.operations.PurgeTxBackupLogOperation
 
onInvocationException(Throwable) - Method in class com.hazelcast.transaction.impl.operations.ReplicateTxBackupLogOperation
 
onInvocationException(Throwable) - Method in class com.hazelcast.transaction.impl.operations.RollbackTxBackupLogOperation
 
onIteration(String, C) - Method in class com.hazelcast.spi.impl.merge.AbstractNamedContainerCollector
Will be called by ContainerIterator#hasNext().
OnJoinCacheOperation - Class in com.hazelcast.cache.impl.operation
Operation executed on joining members so they become aware of CacheConfigs dynamically created via CacheManager.createCache(String, Configuration).
OnJoinCacheOperation() - Constructor for class com.hazelcast.cache.impl.operation.OnJoinCacheOperation
 
OnJoinOp - Class in com.hazelcast.internal.cluster.impl.operations
 
OnJoinOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.OnJoinOp
 
OnJoinOp(Collection<Operation>) - Constructor for class com.hazelcast.internal.cluster.impl.operations.OnJoinOp
 
OnJoinPermissionOperationName - Enum in com.hazelcast.config
Enum of operation names for handling client permissions when the member is joining into the cluster.
OnJoinRegistrationOperation - Class in com.hazelcast.spi.impl.eventservice.impl.operations
 
OnJoinRegistrationOperation() - Constructor for class com.hazelcast.spi.impl.eventservice.impl.operations.OnJoinRegistrationOperation
 
OnJoinRegistrationOperation(Collection<Registration>) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.operations.OnJoinRegistrationOperation
 
onListenerRegister() - Method in interface com.hazelcast.client.impl.spi.EventHandler
This method is called when registration request response is successfully returned from node.
onListenerRegister() - Method in class com.hazelcast.client.impl.spi.impl.SmartClientInvocationService.BackupEventHandler
 
onLoad(Data, Object, ExpiryPolicy, long, boolean, int, boolean) - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
onLoadAll(List<Data>, Object, long) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
onLoadRecord(Data, Record) - Method in class com.hazelcast.map.impl.recordstore.EventJournalWriterRecordStoreMutationObserver
 
onLoadRecord(Data, Record) - Method in class com.hazelcast.map.impl.recordstore.JsonMetadataRecordStoreMutationObserver
 
onLoadRecord(Data, R) - Method in interface com.hazelcast.map.impl.recordstore.RecordStoreMutationObserver
Called when a record is loaded into the observed RecordStore
onMapEvent(MapEvent) - Method in class com.hazelcast.core.EntryAdapter
This method is called when an one of the methods of the EntryListener is not overridden.
onMapEvent(MapEvent) - Method in class com.hazelcast.map.impl.MapListenerAdapter
This method is called when an one of the methods of the EntryListener is not overridden.
onMemberLeft(MemberImpl) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
onMemberLeft(MemberImpl) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
onMemberLeft(MemberImpl) - Method in class com.hazelcast.spi.impl.operationparker.impl.OperationParkerImpl
 
onMemberLeft(MemberImpl) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
onMemberListChange() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
onMemberListChange() - Method in interface com.hazelcast.instance.impl.NodeExtension
Called synchronously when member list changes
onMerge(String) - Method in class com.hazelcast.spi.impl.merge.AbstractMergeRunnable
 
onMessage(Message) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
onMessage(Message) - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicAddMessageListenerMessageTask
 
onMessage(Message) - Method in class com.hazelcast.console.ConsoleApp
 
onMessage(Object) - Method in interface com.hazelcast.internal.cluster.impl.MulticastListener
 
onMessage(Object) - Method in class com.hazelcast.internal.cluster.impl.NodeMulticastListener
 
onMessage(Object) - Method in class com.hazelcast.internal.cluster.impl.SplitBrainMulticastListener
 
onMessage(Message<E>) - Method in class com.hazelcast.topic.impl.reliable.ReliableMessageListenerAdapter
 
onMessage(Message<E>) - Method in interface com.hazelcast.topic.MessageListener
Invoked when a message is received for the added topic.
onMigrationCommit(MigrationInterceptor.MigrationParticipant, MigrationInfo) - Method in interface com.hazelcast.internal.partition.impl.MigrationInterceptor
 
onMigrationComplete(MigrationInterceptor.MigrationParticipant, MigrationInfo, boolean) - Method in interface com.hazelcast.internal.partition.impl.MigrationInterceptor
 
onMigrationRollback(MigrationInterceptor.MigrationParticipant, MigrationInfo) - Method in interface com.hazelcast.internal.partition.impl.MigrationInterceptor
 
onMigrationStart(MigrationInterceptor.MigrationParticipant, MigrationInfo) - Method in interface com.hazelcast.internal.partition.impl.MigrationInterceptor
 
onNewTermCommit(CPGroupId, long) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
onNewTermCommit(CPGroupId, long) - Method in interface com.hazelcast.cp.internal.TermChangeAwareService
Invokes as part of the first commit after a new leader is elected.
onNodeStatusChange(RaftNodeStatus) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Called when RaftNode status changes.
onOutOfMemory(OutOfMemoryError, HazelcastInstance[]) - Method in class com.hazelcast.client.ClientOutOfMemoryHandler
 
onOutOfMemory(OutOfMemoryError, HazelcastInstance[]) - Method in class com.hazelcast.core.OutOfMemoryHandler
When an OutOfMemoryError is caught by Hazelcast threads, this method is called for ALL HazelcastInstances knows by current JVM (actually ClassLoader).
onOutOfMemory(OutOfMemoryError, HazelcastInstance[]) - Method in class com.hazelcast.instance.impl.DefaultOutOfMemoryHandler
 
onOutOfMemory(OutOfMemoryError) - Static method in class com.hazelcast.instance.impl.OutOfMemoryErrorDispatcher
Signals the OutOfMemoryErrorDispatcher that an OutOfMemoryError happened.
onPacketComplete(Packet) - Method in class com.hazelcast.internal.nio.tcp.PacketDecoder
 
onPartitionLost(IPartitionLostEvent) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
onPartitionLost(IPartitionLostEvent) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
onPartitionLost(IPartitionLostEvent) - Method in class com.hazelcast.internal.partition.impl.PartitionEventManager
 
onPartitionLost(IPartitionLostEvent) - Method in class com.hazelcast.map.impl.MapService
 
onPartitionLost(IPartitionLostEvent) - Method in interface com.hazelcast.spi.partition.PartitionAwareService
Invoked when a partition lost is detected
onPartitionMigrate(MigrationInfo) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
onPartitionMigrate(MigrationInfo) - Method in class com.hazelcast.spi.impl.operationparker.impl.OperationParkerImpl
Invalidates all parked operations for the migrated partition and sends a PartitionMigratingException as a response.
onPartitionStateChange() - Method in class com.hazelcast.client.impl.ClientPartitionListenerService
 
onPartitionStateChange() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
onPartitionStateChange() - Method in interface com.hazelcast.instance.impl.NodeExtension
Called synchronously when partition state (partition assignments, version etc) changes
onPingLost(Member) - Method in class com.hazelcast.splitbrainprotection.impl.AbstractPingAwareSplitBrainProtectionFunction
 
onPingLost(Member) - Method in class com.hazelcast.splitbrainprotection.impl.SplitBrainProtectionServiceImpl
 
onPingLost(Member) - Method in interface com.hazelcast.splitbrainprotection.PingAware
Notifies the SplitBrainProtectionFunction of ping loss.
onPingRestored(Member) - Method in class com.hazelcast.splitbrainprotection.impl.AbstractPingAwareSplitBrainProtectionFunction
 
onPingRestored(Member) - Method in class com.hazelcast.splitbrainprotection.impl.SplitBrainProtectionServiceImpl
 
onPingRestored(Member) - Method in interface com.hazelcast.splitbrainprotection.PingAware
Notifies the SplitBrainProtectionFunction of a successful ping after one or more pings to that member were lost.
onProcessExpiredEntry(Data, R, long, long, UUID, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
onPromotionComplete(MigrationInterceptor.MigrationParticipant, Collection<MigrationInfo>, boolean) - Method in interface com.hazelcast.internal.partition.impl.MigrationInterceptor
 
onPromotionStart(MigrationInterceptor.MigrationParticipant, Collection<MigrationInfo>) - Method in interface com.hazelcast.internal.partition.impl.MigrationInterceptor
 
onPut(Data, Object, ExpiryPolicy, UUID, boolean, boolean, R, Object, boolean, boolean, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
onPut(K, V, R, R) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
onPutError(Data, Object, ExpiryPolicy, UUID, boolean, boolean, R, Object, boolean, Throwable) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
onPutError(K, V, R, R, Throwable) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
onPutIfAbsent(Data, Object, ExpiryPolicy, UUID, boolean, R, boolean, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
onPutIfAbsentAsyncInternal(K, V, Data, Data, ClientDelegatingFuture<Boolean>, BiConsumer<Boolean, Throwable>) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
onPutIfAbsentError(Data, Object, ExpiryPolicy, UUID, boolean, R, Throwable) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
onPutIfAbsentSyncInternal(K, V, Data, Data) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
onPutRecord(Data, Record) - Method in class com.hazelcast.map.impl.recordstore.EventJournalWriterRecordStoreMutationObserver
 
onPutRecord(Data, Record) - Method in class com.hazelcast.map.impl.recordstore.JsonMetadataRecordStoreMutationObserver
 
onPutRecord(Data, R) - Method in interface com.hazelcast.map.impl.recordstore.RecordStoreMutationObserver
Called when a new record is added to the RecordStore
onPutSyncInternal(K, V, Data, Data) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
onRaftGroupDestroyed(CPGroupId) - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueService
 
onRaftGroupDestroyed(CPGroupId) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
onRaftGroupDestroyed(CPGroupId) - Method in interface com.hazelcast.cp.internal.RaftNodeLifecycleAwareService
Called on the thread of the Raft group when the given Raft node is destroyed, either gracefully or forcefully.
onRaftGroupDestroyed(CPGroupId) - Method in class com.hazelcast.cp.internal.RaftService
 
onRaftGroupDestroyed(CPGroupId) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
onRaftNodeSteppedDown(CPGroupId) - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueService
 
onRaftNodeSteppedDown(CPGroupId) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
onRaftNodeSteppedDown(CPGroupId) - Method in interface com.hazelcast.cp.internal.RaftNodeLifecycleAwareService
Called on the thread of the Raft group when the given Raft node is stepped down, either because it is shutting down, or it could not be added to the Raft group
onRaftNodeSteppedDown(CPGroupId) - Method in class com.hazelcast.cp.internal.RaftService
 
onRaftNodeSteppedDown(CPGroupId) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
onRead() - Method in class com.hazelcast.client.impl.protocol.util.ClientMessageDecoder
 
onRead() - Method in class com.hazelcast.internal.networking.InboundHandler
A callback to indicate that data is available in the src to be processed.
onRead() - Method in class com.hazelcast.internal.nio.ascii.TextDecoder
 
onRead() - Method in class com.hazelcast.internal.nio.tcp.PacketDecoder
 
onRead() - Method in class com.hazelcast.internal.nio.tcp.SingleProtocolDecoder
 
onRead() - Method in class com.hazelcast.internal.nio.tcp.UnifiedProtocolDecoder
 
onRecordAccess(Data, R, ExpiryPolicy, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
onRecordCreate(K, Data, R) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
onRegister(CacheService, String, String, EventRegistration) - Method in class com.hazelcast.cache.impl.CacheEventListenerAdaptor
 
onRegister(S, String, String, EventRegistration) - Method in interface com.hazelcast.internal.services.NotifiableEventListener
Called when this listener registered to EventService.
onRegister(Object, String, String, EventRegistration) - Method in class com.hazelcast.map.impl.MapService
 
onRegistryRestored(LockRegistry) - Method in class com.hazelcast.cp.internal.datastructures.lock.LockService
 
onRegistryRestored(RR) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
onRemove(Data, Object, UUID, boolean, R, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
onRemove(Data, String, int, boolean) - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
onRemove(K, R, boolean) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
onRemove(long, IndexOperationStats, Index.OperationSource) - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
onRemove(long, IndexOperationStats, Index.OperationSource) - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
onRemove(long, IndexOperationStats, Index.OperationSource) - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Invoked by the associated index after every remove operation.
onRemoveAsyncInternal(Object, Data, ClientDelegatingFuture, BiConsumer<Object, Throwable>) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
onRemoveError(Data, Object, UUID, boolean, R, boolean, Throwable) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
onRemoveError(K, R, boolean, Throwable) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
onRemoveRecord(Data, Record) - Method in class com.hazelcast.map.impl.recordstore.EventJournalWriterRecordStoreMutationObserver
 
onRemoveRecord(Data, Record) - Method in class com.hazelcast.map.impl.recordstore.JsonMetadataRecordStoreMutationObserver
 
onRemoveRecord(Data, R) - Method in interface com.hazelcast.map.impl.recordstore.RecordStoreMutationObserver
Called when a record is removed from the observed RecordStore
onRemoveSyncInternal(Object, Data) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
onReplace(Data, Object, Object, ExpiryPolicy, UUID, boolean, R, boolean, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
onReplaceAndGetAsync(K, V, Data, Data, ClientDelegatingFuture<T>, BiConsumer<T, Throwable>) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
onReplaceError(Data, Object, Object, ExpiryPolicy, UUID, boolean, R, boolean, boolean, Throwable) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
onReplaceInternalAsync(K, V, Data, Data, ClientDelegatingFuture<T>, BiConsumer<T, Throwable>) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
onReplicationEvent(WanReplicationEvent, WanAcknowledgeType) - Method in interface com.hazelcast.internal.services.ReplicationSupportingService
Processes a WAN replication event.
onReplicationEvent(WanReplicationEvent, WanAcknowledgeType) - Method in class com.hazelcast.map.impl.MapService
 
onReplicationPutRecord(Data, Record) - Method in class com.hazelcast.map.impl.recordstore.EventJournalWriterRecordStoreMutationObserver
 
onReplicationPutRecord(Data, Record) - Method in class com.hazelcast.map.impl.recordstore.JsonMetadataRecordStoreMutationObserver
 
onReplicationPutRecord(Data, R) - Method in interface com.hazelcast.map.impl.recordstore.RecordStoreMutationObserver
Called when a new record is added to the RecordStore due to replication
onReset() - Method in class com.hazelcast.map.impl.recordstore.EventJournalWriterRecordStoreMutationObserver
 
onReset() - Method in class com.hazelcast.map.impl.recordstore.JsonMetadataRecordStoreMutationObserver
 
onReset() - Method in interface com.hazelcast.map.impl.recordstore.RecordStoreMutationObserver
Called when the observed RecordStore is being reset.
onResponse(V) - Method in interface com.hazelcast.core.ExecutionCallback
Called when an execution is completed successfully.
onResponse(Member, Object) - Method in interface com.hazelcast.core.MultiExecutionCallback
Called when an execution is completed on a member.
onResponse(E) - Method in class com.hazelcast.spi.impl.SimpleExecutionCallback
 
onResult(T) - Method in interface com.hazelcast.query.extractor.ValueCallback
Notifies about a value passed as an argument
onRunStart() - Method in class com.hazelcast.spi.impl.merge.AbstractMergeRunnable
 
onSecurityServiceUpdated(SecurityService) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
onServiceInitialized(ClusterWideConfigurationService) - Method in interface com.hazelcast.internal.dynamicconfig.DynamicConfigListener
Called when a ClusterWideConfigurationService is initialized.
onServiceInitialized(ClusterWideConfigurationService) - Method in class com.hazelcast.internal.dynamicconfig.EmptyDynamicConfigListener
 
onSessionClose(long, Map<Long, Object>) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatch
 
onSessionClose(long, Map<Long, Object>) - Method in class com.hazelcast.cp.internal.datastructures.lock.Lock
Releases the lock if the current lock holder's session is closed.
onSessionClose(long, Map<Long, Object>) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.Semaphore
Releases permits of the closed session.
onSessionClose(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
onSessionClose(long, Map<Long, Object>) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.BlockingResource
Called when a session is closed.
onSessionClose(CPGroupId, long) - Method in interface com.hazelcast.cp.internal.session.SessionAwareService
Called when a session is closed.
onSetCallId(long) - Method in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
onSetCallId(long) - Method in class com.hazelcast.spi.impl.operationservice.Operation
Called every time a new callId is set on the operation.
onShutdown() - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
onShutdown() - Method in class com.hazelcast.client.impl.spi.ClientProxy
Called before client shutdown.
onShutdown(long, TimeUnit) - Method in class com.hazelcast.cp.internal.RaftService
 
onShutdown(long, TimeUnit) - Method in class com.hazelcast.cp.internal.session.ProxySessionManagerService
 
onShutdown(long, TimeUnit) - Method in class com.hazelcast.internal.crdt.CRDTReplicationMigrationService
Attempts to replicate only the unreplicated CRDT state to any non-local member in the cluster.
onShutdown() - Method in class com.hazelcast.internal.eviction.ExpirationManager
Called upon shutdown of MapService
onShutdown(long, TimeUnit) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
onShutdown(long, TimeUnit) - Method in interface com.hazelcast.internal.services.GracefulShutdownAwareService
A hook method that's called during graceful shutdown to provide safety for data managed by this service.
onShutdown() - Method in class com.hazelcast.spi.impl.operationparker.impl.WaitSet
 
onShutdownRequest(Member) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
onShutdownResponse() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
onShuttingDown() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
onShuttingDown() - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
 
onShuttingDown() - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
 
onStart() - Method in class com.hazelcast.internal.diagnostics.BuildInfoPlugin
 
onStart() - Method in class com.hazelcast.internal.diagnostics.ConfigPropertiesPlugin
 
onStart() - Method in class com.hazelcast.internal.diagnostics.DiagnosticsPlugin
 
onStart() - Method in class com.hazelcast.internal.diagnostics.EventQueuePlugin
 
onStart() - Method in class com.hazelcast.internal.diagnostics.InvocationPlugin
 
onStart() - Method in class com.hazelcast.internal.diagnostics.MemberHazelcastInstanceInfoPlugin
 
onStart() - Method in class com.hazelcast.internal.diagnostics.MemberHeartbeatPlugin
 
onStart() - Method in class com.hazelcast.internal.diagnostics.MetricsPlugin
 
onStart() - Method in class com.hazelcast.internal.diagnostics.NetworkingImbalancePlugin
 
onStart() - Method in class com.hazelcast.internal.diagnostics.OperationHeartbeatPlugin
 
onStart() - Method in class com.hazelcast.internal.diagnostics.OperationThreadSamplerPlugin
 
onStart() - Method in class com.hazelcast.internal.diagnostics.OverloadedConnectionsPlugin
 
onStart() - Method in class com.hazelcast.internal.diagnostics.PendingInvocationsPlugin
 
onStart() - Method in class com.hazelcast.internal.diagnostics.SlowOperationPlugin
 
onStart() - Method in class com.hazelcast.internal.diagnostics.StoreLatencyPlugin
 
onStart() - Method in class com.hazelcast.internal.diagnostics.SystemLogPlugin
 
onStart() - Method in class com.hazelcast.internal.diagnostics.SystemPropertiesPlugin
 
onStartAsyncOperation(Operation) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
onStartAsyncOperation(Operation) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Should be called when an asynchronous operations not running on a operation thread is running.
onStartDeserialization() - Static method in class com.hazelcast.internal.usercodedeployment.impl.ClassLocator
 
onStartDeserialization() - Static method in class com.hazelcast.internal.usercodedeployment.impl.ThreadLocalClassCache
 
onStore() - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
onStore() - Method in interface com.hazelcast.map.impl.record.Record
 
onStore(Record) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
onStoreCollection(Store) - Method in class com.hazelcast.spi.impl.merge.AbstractSplitBrainHandlerService
Final cleanup before starting merge after StoreCollector collects a store.
onSuccessfulConnection(Address) - Method in interface com.hazelcast.internal.nio.IOService
 
onSuccessfulConnection(Address) - Method in class com.hazelcast.internal.nio.NodeIOService
 
onThreadStart(Thread) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
onThreadStart(Thread) - Method in interface com.hazelcast.instance.impl.NodeExtension
Called on thread start to inject/intercept extension specific logic, like; registering thread in some service, executing a special method before thread starts to do its own task.
onThreadStop(Thread) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
onThreadStop(Thread) - Method in interface com.hazelcast.instance.impl.NodeExtension
Called before a thread stops to clean/release injected by NodeExtension.onThreadStart(Thread).
onUpdate(Data, Object, R, ExpiryPolicy, long, boolean, int, boolean) - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
onUpdate(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
onUpdate(long) - Method in interface com.hazelcast.map.impl.record.Record
 
onUpdate(long, IndexOperationStats, Index.OperationSource) - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
onUpdate(long, IndexOperationStats, Index.OperationSource) - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
onUpdate(long, IndexOperationStats, Index.OperationSource) - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Invoked by the associated index after every update operation.
onUpdateExpiryPolicy(Data, R, Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
onUpdateExpiryPolicyError(Data, R, Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
onUpdateRecord(Data, R, Object, Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
onUpdateRecord(Data, Record, Object) - Method in class com.hazelcast.map.impl.recordstore.EventJournalWriterRecordStoreMutationObserver
 
onUpdateRecord(Data, Record, Object) - Method in class com.hazelcast.map.impl.recordstore.JsonMetadataRecordStoreMutationObserver
 
onUpdateRecord(Data, R, Object) - Method in interface com.hazelcast.map.impl.recordstore.RecordStoreMutationObserver
Called when a new record is updated in the observed RecordStore
onUpdateRecordError(Data, R, Object, Data, Data, Throwable) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
onWaitExpire() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
 
onWaitExpire() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
 
onWaitExpire() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPeekOperation
 
onWaitExpire() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferOperation
 
onWaitExpire() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollOperation
 
onWaitExpire() - Method in class com.hazelcast.durableexecutor.impl.operations.RetrieveAndDisposeResultOperation
 
onWaitExpire() - Method in class com.hazelcast.durableexecutor.impl.operations.RetrieveResultOperation
 
onWaitExpire() - Method in class com.hazelcast.internal.journal.EventJournalReadOperation
 
onWaitExpire() - Method in class com.hazelcast.internal.locksupport.operations.LockOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.operation.AwaitMapFlushOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.operation.BasePutOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.operation.ContainsKeyOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.operation.DeleteOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.operation.EntryOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.operation.EvictOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.operation.GetEntryViewOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.operation.GetOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.operation.LockAwareOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.operation.PutTransientOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.operation.RemoveIfSameOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.operation.SetTtlOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.operation.TryPutOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
 
onWaitExpire() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
 
onWaitExpire() - Method in class com.hazelcast.multimap.impl.operations.AbstractBackupAwareMultiMapOperation
 
onWaitExpire() - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
 
onWaitExpire() - Method in class com.hazelcast.multimap.impl.operations.CountOperation
 
onWaitExpire() - Method in class com.hazelcast.multimap.impl.operations.DeleteOperation
 
onWaitExpire() - Method in class com.hazelcast.multimap.impl.operations.GetAllOperation
 
onWaitExpire() - Method in class com.hazelcast.multimap.impl.operations.PutOperation
 
onWaitExpire() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllOperation
 
onWaitExpire() - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
 
onWaitExpire() - Method in class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
 
onWaitExpire() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
 
onWaitExpire() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
 
onWaitExpire() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetResultOperation
 
onWaitExpire() - Method in interface com.hazelcast.spi.impl.operationservice.BlockingOperation
 
onWaitKeyExpire(LockInvocationKey) - Method in class com.hazelcast.cp.internal.datastructures.lock.Lock
 
onWaitKeyExpire(AcquireInvocationKey) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.Semaphore
 
onWaitKeyExpire(W) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.BlockingResource
 
onWrite() - Method in class com.hazelcast.client.impl.connection.nio.ClientProtocolEncoder
 
onWrite() - Method in class com.hazelcast.client.impl.protocol.util.ClientMessageEncoder
 
onWrite() - Method in class com.hazelcast.internal.networking.OutboundHandler
A callback to indicate that this OutboundHandler should be processed.
onWrite() - Method in class com.hazelcast.internal.nio.ascii.TextEncoder
 
onWrite() - Method in class com.hazelcast.internal.nio.tcp.MemberProtocolEncoder
 
onWrite() - Method in class com.hazelcast.internal.nio.tcp.PacketEncoder
 
onWrite() - Method in class com.hazelcast.internal.nio.tcp.UnifiedProtocolEncoder
 
op - Variable in class com.hazelcast.spi.impl.operationservice.impl.Invocation
The Operation this invocation is evaluating.
op - Variable in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
 
OP_FACTORY_WRAPPER - Static variable in class com.hazelcast.client.impl.ClientDataSerializerHook
 
open() - Method in interface com.hazelcast.cache.impl.ICacheInternal
Opens cache if available (not destroyed).
open(String, Object...) - Method in class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
open() - Method in class com.hazelcast.cp.internal.raft.impl.persistence.NopRaftStateStore
 
open() - Method in interface com.hazelcast.cp.internal.raft.impl.persistence.RaftStateStore
Initializes the store before starting to persist Raft state.
openConnection(URL) - Method in interface com.hazelcast.internal.management.ManagementCenterConnectionFactory
 
operateOnKey(Data) - Method in class com.hazelcast.map.impl.operation.EntryOperator
 
operateOnKeyValue(Data, Object) - Method in class com.hazelcast.map.impl.operation.EntryOperator
 
OperatingSystemMetricSet - Class in com.hazelcast.internal.metrics.metricsets
A Metric set for exposing OperatingSystemMXBean metrics.
OperatingSystemMXBeanSupport - Class in com.hazelcast.internal.util
Support class for reading attributes from OperatingSystemMXBean.
operation() - Method in class com.hazelcast.cp.internal.raft.impl.log.LogEntry
 
operation - Variable in class com.hazelcast.internal.management.dto.SlowOperationDTO
 
Operation - Class in com.hazelcast.spi.impl.operationservice
An operation could be compared to a Runnable.
Operation() - Constructor for class com.hazelcast.spi.impl.operationservice.Operation
 
OPERATION_BACKUP_TIMEOUT_MILLIS - Static variable in class com.hazelcast.client.properties.ClientProperty
If an operation has backups, this property specifies how long the invocation will wait for acks from the backup replicas.
OPERATION_BACKUP_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
If an operation has backups, this property specifies how long the invocation will wait for acks from the backup replicas.
OPERATION_CALL_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
OPERATION_CAPACITY - Static variable in class com.hazelcast.ringbuffer.impl.operations.GenericOperation
 
OPERATION_CONTROL - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
OPERATION_HEAD - Static variable in class com.hazelcast.ringbuffer.impl.operations.GenericOperation
 
OPERATION_REMAINING_CAPACITY - Static variable in class com.hazelcast.ringbuffer.impl.operations.GenericOperation
 
OPERATION_SIZE - Static variable in class com.hazelcast.ringbuffer.impl.operations.GenericOperation
 
OPERATION_TAIL - Static variable in class com.hazelcast.ringbuffer.impl.operations.GenericOperation
 
OPERATION_TIMEOUT - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
OPERATION_WAIT_TIMEOUT_MINUTES - Static variable in class com.hazelcast.map.impl.querycache.subscriber.AbstractQueryCacheEndToEndConstructor
 
OperationAccessor - Class in com.hazelcast.spi.impl.operationservice
Allows access to certain attributes on an Operation.
OperationControl - Class in com.hazelcast.spi.impl.operationservice
Content of an Operation Control packet: a list of operations the remote member started on this member which are still running; a list of operations this member wants to cancel on the remote member. Operations are identified by their call ID.
OperationControl() - Constructor for class com.hazelcast.spi.impl.operationservice.OperationControl
 
OperationControl(long[], long[]) - Constructor for class com.hazelcast.spi.impl.operationservice.OperationControl
 
OperationDescriptors - Class in com.hazelcast.internal.diagnostics
Converts an operation class into something readable.
operationDetails - Variable in class com.hazelcast.internal.management.dto.SlowOperationInvocationDTO
 
OperationExecutor - Interface in com.hazelcast.spi.impl.operationexecutor
The OperationExecutor is responsible for scheduling work (packets/operations) to be executed.
OperationExecutorImpl - Class in com.hazelcast.spi.impl.operationexecutor.impl
A OperationExecutor that schedules: partition specific operations to a specific partition-operation-thread (using a mod on the partition ID) non specific operations to generic-operation-threads The OperationExecutorImpl.execute(Object, int, boolean) accepts an Object instead of a runnable to prevent needing to create wrapper runnables around tasks.
OperationExecutorImpl(HazelcastProperties, LoggingService, Address, OperationRunnerFactory, NodeExtension, String, ClassLoader) - Constructor for class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
operationExecutorQueueSize - Variable in class com.hazelcast.internal.management.dto.OperationServiceDTO
 
OperationFactory - Interface in com.hazelcast.spi.impl.operationservice
A Factory for creating Operation instances.
OperationFactoryWrapper - Class in com.hazelcast.client.impl.operations
 
OperationFactoryWrapper() - Constructor for class com.hazelcast.client.impl.operations.OperationFactoryWrapper
 
OperationFactoryWrapper(OperationFactory, UUID) - Constructor for class com.hazelcast.client.impl.operations.OperationFactoryWrapper
 
OperationHeartbeatPlugin - Class in com.hazelcast.internal.diagnostics
A diagnostics plugin that checks how the network is behaving by checking deviations in Operation-heartbeats to assist with network related problems like split-brain.
OperationHeartbeatPlugin(NodeEngineImpl) - Constructor for class com.hazelcast.internal.diagnostics.OperationHeartbeatPlugin
 
OperationHostileThread - Interface in com.hazelcast.spi.impl.operationexecutor
Marker interface for threads that are not allowed to run operations.
operationList - Variable in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
 
operationMap - Variable in class com.hazelcast.internal.jmx.HazelcastMBean
 
OperationParker - Interface in com.hazelcast.spi.impl.operationparker
A service to park/unpark BlockingOperation.
OperationParkerImpl - Class in com.hazelcast.spi.impl.operationparker.impl
 
OperationParkerImpl(NodeEngineImpl) - Constructor for class com.hazelcast.spi.impl.operationparker.impl.OperationParkerImpl
 
operationProvider - Variable in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
 
operationProviderCache - Variable in class com.hazelcast.cache.impl.AbstractCacheService
 
OperationQueue - Interface in com.hazelcast.spi.impl.operationexecutor.impl
The OperationQueue is the queue used to schedule operations/tasks on an OperationThread.
OperationQueueImpl - Class in com.hazelcast.spi.impl.operationexecutor.impl
 
OperationQueueImpl() - Constructor for class com.hazelcast.spi.impl.operationexecutor.impl.OperationQueueImpl
 
OperationQueueImpl(BlockingQueue<Object>, Queue<Object>) - Constructor for class com.hazelcast.spi.impl.operationexecutor.impl.OperationQueueImpl
 
OperationResponseHandler<O extends Operation> - Interface in com.hazelcast.spi.impl.operationservice
A handler for the OperationService when it has calculated a response.
OperationResponseHandlerFactory - Class in com.hazelcast.spi.impl.operationservice
 
operationRunner(int) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.GenericOperationThread
 
operationRunner(int) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationThread
 
operationRunner(int) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.PartitionOperationThread
For each partition there is a OperationRunner instance.
OperationRunner - Class in com.hazelcast.spi.impl.operationexecutor
The OperationRunner is responsible for the actual running of operations.
OperationRunner(int) - Constructor for class com.hazelcast.spi.impl.operationexecutor.OperationRunner
 
OperationRunnerFactory - Interface in com.hazelcast.spi.impl.operationexecutor
A Factory for creating OperationRunner instances.
operations() - Method in class com.hazelcast.cp.internal.raft.impl.state.QueryState
Returns the queries waiting to be executed.
Operations - Class in com.hazelcast.spi.impl.operationservice
Utility class that contains helper methods related to Operation
operationService - Variable in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
 
operationService - Variable in class com.hazelcast.map.impl.query.PartitionScanRunner
 
operationService - Variable in class com.hazelcast.map.impl.query.QueryRunner
 
operationService - Variable in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
 
operationService - Variable in class com.hazelcast.spi.impl.operationservice.Offload
 
OperationService - Interface in com.hazelcast.spi.impl.operationservice
The OperationService is responsible for executing operations.
OperationServiceDTO - Class in com.hazelcast.internal.management.dto
A Serializable DTO for OperationServiceMBean.
OperationServiceDTO() - Constructor for class com.hazelcast.internal.management.dto.OperationServiceDTO
 
OperationServiceDTO(OperationServiceImpl) - Constructor for class com.hazelcast.internal.management.dto.OperationServiceDTO
 
OperationServiceImpl - Class in com.hazelcast.spi.impl.operationservice.impl
This is the implementation of the OperationServiceImpl.
OperationServiceImpl(NodeEngineImpl) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
OperationServiceMBean - Class in com.hazelcast.internal.jmx
Management bean for OperationService
OperationServiceMBean(HazelcastInstance, OperationServiceImpl, ManagementService) - Constructor for class com.hazelcast.internal.jmx.OperationServiceMBean
 
operationsToCancel() - Method in class com.hazelcast.spi.impl.operationservice.OperationControl
 
OperationThread - Class in com.hazelcast.spi.impl.operationexecutor.impl
The OperationThread is responsible for processing operations, packets containing operations and runnable's.
OperationThread(String, int, OperationQueue, ILogger, NodeExtension, boolean, ClassLoader) - Constructor for class com.hazelcast.spi.impl.operationexecutor.impl.OperationThread
 
operationThreadCount - Variable in class com.hazelcast.internal.management.dto.OperationServiceDTO
 
OperationThreadSamplerPlugin - Class in com.hazelcast.internal.diagnostics
The OperationThreadSamplerPlugin is a DiagnosticsPlugin that samples the operations threads and checks with operations/tasks are running.
OperationThreadSamplerPlugin(NodeEngineImpl) - Constructor for class com.hazelcast.internal.diagnostics.OperationThreadSamplerPlugin
 
OperationTimeoutException - Exception in com.hazelcast.core
An unchecked version of TimeoutException.
OperationTimeoutException() - Constructor for exception com.hazelcast.core.OperationTimeoutException
 
OperationTimeoutException(String) - Constructor for exception com.hazelcast.core.OperationTimeoutException
 
OperationTimeoutException(String, String) - Constructor for exception com.hazelcast.core.OperationTimeoutException
 
OperationTimeoutException(String, Throwable) - Constructor for exception com.hazelcast.core.OperationTimeoutException
 
operator(MapOperation) - Static method in class com.hazelcast.map.impl.operation.EntryOperator
 
operator(MapOperation, Object) - Static method in class com.hazelcast.map.impl.operation.EntryOperator
 
operator(MapOperation, Object, Predicate) - Static method in class com.hazelcast.map.impl.operation.EntryOperator
 
operator - Variable in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
 
optimize(Predicate<K, V>, Indexes) - Method in class com.hazelcast.query.impl.predicates.EmptyOptimizer
 
optimize(Predicate<K, V>, Indexes) - Method in interface com.hazelcast.query.impl.predicates.QueryOptimizer
 
optimize(Predicate<K, V>, Indexes) - Method in class com.hazelcast.query.impl.predicates.RuleBasedQueryOptimizer
 
optional() - Method in interface com.hazelcast.config.properties.PropertyDefinition
Defines if this property is optional or not.
optional() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
 
options() - Method in interface com.hazelcast.internal.networking.Channel
Returns the ChannelOptions of this Channel.
options() - Method in class com.hazelcast.internal.networking.nio.NioChannel
 
or(ClientSelector...) - Static method in class com.hazelcast.client.impl.ClientSelectors
 
or(MemberSelector...) - Static method in class com.hazelcast.cluster.memberselector.MemberSelectors
Selects a member when one of the selectors succeed
or(BiPredicateEx<? super T, ? super U>) - Method in interface com.hazelcast.internal.util.function.BiPredicateEx
or(PredicateEx<? super T>) - Method in interface com.hazelcast.internal.util.function.PredicateEx
or(Predicate) - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
or(Predicate) - Method in interface com.hazelcast.query.PredicateBuilder
 
or(Predicate...) - Static method in class com.hazelcast.query.Predicates
Creates an or predicate that will perform the logical or operation on the given predicates.
OR_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
orderAndLimit(PagingPredicate, Map.Entry<Integer, Map.Entry>) - Method in class com.hazelcast.map.impl.query.AggregationResult
 
orderAndLimit(PagingPredicate, Map.Entry<Integer, Map.Entry>) - Method in class com.hazelcast.map.impl.query.QueryResult
 
orderAndLimit(PagingPredicate, Map.Entry<Integer, Map.Entry>) - Method in interface com.hazelcast.map.impl.query.Result
Performs the order-and-limit operation on this result for the given paging predicate.
OrderedIndexStore - Class in com.hazelcast.query.impl
Store indexes rankly.
OrderedIndexStore(IndexCopyBehavior) - Constructor for class com.hazelcast.query.impl.OrderedIndexStore
 
ORDERING_LOCKS_LENGTH - Static variable in class com.hazelcast.topic.impl.TopicService
 
ordinal() - Method in class com.hazelcast.spi.impl.operationservice.CallStatus
Returns the ordinal value (useful for doing a switch case based on the type of CallStatus).
original - Variable in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
OrMemberSelector - Class in com.hazelcast.cluster.memberselector.impl
Selects a member if one of the sub-selectors succeed
OrMemberSelector(MemberSelector...) - Constructor for class com.hazelcast.cluster.memberselector.impl.OrMemberSelector
 
OrPredicate - Class in com.hazelcast.query.impl.predicates
Or Predicate
OrPredicate() - Constructor for class com.hazelcast.query.impl.predicates.OrPredicate
 
OrPredicate(Predicate...) - Constructor for class com.hazelcast.query.impl.predicates.OrPredicate
 
OrResultSet - Class in com.hazelcast.query.impl
Or result set for Predicates.
OrResultSet(List<Set<QueryableEntry>>) - Constructor for class com.hazelcast.query.impl.OrResultSet
 
OrToInVisitor - Class in com.hazelcast.query.impl.predicates
Transforms predicate (attribute = 1 or attribute = 2 or attribute = 3) into (attribute in (1, 2, 3) InPredicate is easier to evaluate in both indexed and non-indexed scenarios.
OrToInVisitor() - Constructor for class com.hazelcast.query.impl.predicates.OrToInVisitor
 
OS - Static variable in class com.hazelcast.internal.util.OsHelper
OS name in lower case.
OSGiScriptEngineFactory - Class in com.hazelcast.osgi.impl
This is a wrapper class for the ScriptEngineFactory class that deals with context class loader issues It is necessary because engines (at least ruby) use the context classloader to find their resources (i.e., their "native" classes)
OSGiScriptEngineFactory(ScriptEngineFactory, ClassLoader) - Constructor for class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
 
OSGiScriptEngineManager - Class in com.hazelcast.osgi.impl
This class acts as a delegate for all the available ScriptEngineManagers.
OSGiScriptEngineManager(BundleContext) - Constructor for class com.hazelcast.osgi.impl.OSGiScriptEngineManager
 
OsHelper - Class in com.hazelcast.internal.util
Helper methods related to operating system on which the code is actually running.
OUT_OF_MEMORY_ERROR - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
OutboundFrame - Interface in com.hazelcast.internal.networking
Represents a payload to can be written to a Channel There are different types of OutboundFrame: Packet: for member to member and old-client to member communication TextMessage: for memcached and rest communication ClientMessage: for the new client to member communication Till so far, all communication over a single connection, will be of a single Frame-class.
OutboundHandler<S,D> - Class in com.hazelcast.internal.networking
The OutboundHandler is a ChannelHandler for outbound traffic.
OutboundHandler() - Constructor for class com.hazelcast.internal.networking.OutboundHandler
 
OutboundOperationHandler - Class in com.hazelcast.spi.impl.operationservice.impl
Responsible for sending Operations to another member.
OutboundOperationHandler(Node, Address, InternalSerializationService) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.OutboundOperationHandler
 
outboundPipeline() - Method in interface com.hazelcast.internal.networking.Channel
Returns the OutboundPipeline that belongs to this Channel.
outboundPipeline() - Method in class com.hazelcast.internal.networking.nio.NioChannel
 
OutboundPipeline - Interface in com.hazelcast.internal.networking
The outbound pipeline of a Channel.
OutboundResponseHandler - Class in com.hazelcast.spi.impl.operationservice.impl
An OperationResponseHandler that is used for a remotely executed Operation.
OutOfMemoryErrorDispatcher - Class in com.hazelcast.instance.impl
 
OutOfMemoryHandler - Class in com.hazelcast.core
Handler for OutOfMemoryError.
OutOfMemoryHandler() - Constructor for class com.hazelcast.core.OutOfMemoryHandler
 
OutOfMemoryHandlerHelper - Class in com.hazelcast.instance.impl
Helper class for OutOfMemoryHandlers to close sockets, stop threads, release allocated resources of an HazelcastInstanceImpl.
outputThreadCount(int) - Method in class com.hazelcast.internal.networking.nio.NioNetworking.Context
 
overflowPolicy - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferAddAllCodec.RequestParameters
the overflowPolicy to use
overflowPolicy - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferAddCodec.RequestParameters
the OverflowPolicy to use.
OverflowPolicy - Enum in com.hazelcast.ringbuffer
Using this policy one can control the behavior what should to be done when an item is about to be added to the ringbuffer, but there is 0 remaining capacity.
OverloadedConnectionsPlugin - Class in com.hazelcast.internal.diagnostics
The OverloadedConnectionsPlugin checks all the connections and samples the content of the packet queues if the size is above a certain threshold.
OverloadedConnectionsPlugin(NodeEngineImpl) - Constructor for class com.hazelcast.internal.diagnostics.OverloadedConnectionsPlugin
 
override(int) - Static method in class com.hazelcast.internal.util.RuntimeAvailableProcessors
Overrides the number of available processors returned by the method RuntimeAvailableProcessors.get().
overrideByteOrder() - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
overrideDefault(int) - Static method in class com.hazelcast.internal.util.RuntimeAvailableProcessors
Overrides the number of available processors that are set by the method RuntimeAvailableProcessors.override(int)
OwnedEntryCostEstimatorFactory - Class in com.hazelcast.map.impl
Static factory methods for various entry cost estimators.
owner() - Method in interface com.hazelcast.internal.networking.nio.MigratablePipeline
Get NioThread currently owning this pipeline.
owner - Variable in class com.hazelcast.internal.networking.nio.NioPipeline
 
owner() - Method in class com.hazelcast.internal.networking.nio.NioPipeline
Returns the NioThread owning this pipeline.

P

Packet - Class in com.hazelcast.internal.nio
A Packet is a piece of data sent over the wire.
Packet() - Constructor for class com.hazelcast.internal.nio.Packet
 
Packet(byte[]) - Constructor for class com.hazelcast.internal.nio.Packet
 
Packet(byte[], int) - Constructor for class com.hazelcast.internal.nio.Packet
 
Packet.Type - Enum in com.hazelcast.internal.nio
 
PacketDecoder - Class in com.hazelcast.internal.nio.tcp
The InboundHandler for member to member communication.
PacketDecoder(TcpIpConnection, Consumer<Packet>) - Constructor for class com.hazelcast.internal.nio.tcp.PacketDecoder
 
PacketDispatcher - Class in com.hazelcast.spi.impl
A Consumer that dispatches the Packet to the right service.
PacketDispatcher(ILogger, Consumer<Packet>, Consumer<Packet>, Consumer<Packet>, Consumer<Packet>, Consumer<Packet>) - Constructor for class com.hazelcast.spi.impl.PacketDispatcher
 
PacketEncoder - Class in com.hazelcast.internal.nio.tcp
A OutboundHandler that for member to member communication.
PacketEncoder() - Constructor for class com.hazelcast.internal.nio.tcp.PacketEncoder
 
PacketIOHelper - Class in com.hazelcast.internal.nio
Responsible for writing or reading an Packet.
PacketIOHelper() - Constructor for class com.hazelcast.internal.nio.PacketIOHelper
 
packetVersion - Variable in class com.hazelcast.internal.cluster.impl.JoinMessage
 
PAGING_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
PagingPredicate<K,V> - Interface in com.hazelcast.query
This interface is a special Predicate which helps to get a page-by-page result of a query.
pagingPredicate(int) - Static method in class com.hazelcast.query.Predicates
Creates a paging predicate with a page size.
pagingPredicate(Predicate, int) - Static method in class com.hazelcast.query.Predicates
Creates a paging predicate with an inner predicate and page size.
pagingPredicate(Comparator<Map.Entry<K, V>>, int) - Static method in class com.hazelcast.query.Predicates
Creates a paging predicate with a comparator and page size.
pagingPredicate(Predicate<K, V>, Comparator<Map.Entry<K, V>>, int) - Static method in class com.hazelcast.query.Predicates
Creates a paging predicate with an inner predicate, comparator and page size.
PagingPredicateAccessor - Class in com.hazelcast.query
This class provides paging accessor of predicate.
PagingPredicateImpl<K,V> - Class in com.hazelcast.query.impl.predicates
Implementaiton of PagingPredicate.
PagingPredicateImpl() - Constructor for class com.hazelcast.query.impl.predicates.PagingPredicateImpl
Used for serialization internally
PagingPredicateImpl(int) - Constructor for class com.hazelcast.query.impl.predicates.PagingPredicateImpl
Construct with a pageSize results will not be filtered results will be natural ordered throws IllegalArgumentException if pageSize is not greater than 0
PagingPredicateImpl(Predicate, int) - Constructor for class com.hazelcast.query.impl.predicates.PagingPredicateImpl
Construct with an inner predicate and pageSize results will be filtered via inner predicate results will be natural ordered throws IllegalArgumentException if pageSize is not greater than 0 throws IllegalArgumentException if inner predicate is also a PagingPredicate
PagingPredicateImpl(Comparator<Map.Entry<K, V>>, int) - Constructor for class com.hazelcast.query.impl.predicates.PagingPredicateImpl
Construct with a comparator and pageSize results will not be filtered results will be ordered via comparator throws IllegalArgumentException if pageSize is not greater than 0
PagingPredicateImpl(Predicate<K, V>, Comparator<Map.Entry<K, V>>, int) - Constructor for class com.hazelcast.query.impl.predicates.PagingPredicateImpl
Construct with an inner predicate, comparator and pageSize results will be filtered via inner predicate results will be ordered via comparator throws IllegalArgumentException if pageSize is not greater than 0 throws IllegalArgumentException if inner predicate is also a PagingPredicate
PARALLEL_OPERATION_FACTORY - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
ParallelAccumulationExecutor - Class in com.hazelcast.map.impl.query
Implementation of the AccumulationExecutor that runs the accumulation in a multi-threaded way.
ParallelAccumulationExecutor(ManagedExecutorService, SerializationService, int) - Constructor for class com.hazelcast.map.impl.query.ParallelAccumulationExecutor
 
ParallelPartitionScanExecutor - Class in com.hazelcast.map.impl.query
Implementation of the PartitionScanExecutor which executes the partition scan in a parallel-fashion delegating to the underlying executor.
ParallelPartitionScanExecutor(PartitionScanRunner, ManagedExecutorService, int) - Constructor for class com.hazelcast.map.impl.query.ParallelPartitionScanExecutor
 
parameters - Variable in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
parameters() - Method in interface com.hazelcast.internal.auditlog.AuditableEvent
 
parameters(Map<String, Object>) - Method in interface com.hazelcast.internal.auditlog.EventBuilder
 
parameters(Map<String, Object>) - Method in class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService.Builder
 
parameters() - Method in class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService.NoOpEvent
 
Parameters - Interface in com.hazelcast.security
This interface is used to pass parameters of a method call to a SecurityInterceptor.
parent() - Method in class com.hazelcast.internal.yaml.AbstractYamlNode
 
parent() - Method in interface com.hazelcast.internal.yaml.YamlNode
Returns the parent of the given node
park(BlockingOperation) - Method in class com.hazelcast.spi.impl.operationparker.impl.OperationParkerImpl
 
park(BlockingOperation) - Method in class com.hazelcast.spi.impl.operationparker.impl.WaitSet
 
park(BlockingOperation) - Method in interface com.hazelcast.spi.impl.operationparker.OperationParker
Parks the Operation until it is unparked by a OperationParker.unpark(Notifier) call or by a timeout specified by the BlockingOperation.getWaitTimeout().
parse(InputStream) - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
parse(InputStream) - Method in class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
 
parse(InputStream) - Method in class com.hazelcast.config.AbstractXmlConfigBuilder
Reads XML from InputStream and parses.
parse(InputStream) - Method in class com.hazelcast.config.XmlConfigBuilder
 
parse(String) - Static method in class com.hazelcast.internal.json.Json
Parses the given input string as JSON.
parse(Reader) - Static method in class com.hazelcast.internal.json.Json
Reads the entire input from the given reader and parses it as JSON.
parse(String) - Method in class com.hazelcast.internal.json.JsonParser
Parses the given input string.
parse(Reader) - Method in class com.hazelcast.internal.json.JsonParser
Reads the entire input from the given reader and parses it as JSON.
parse(Reader, int) - Method in class com.hazelcast.internal.json.JsonParser
Reads the entire input from the given reader and parses it as JSON.
parse(Reader) - Method in class com.hazelcast.internal.json.JsonReducedValueParser
Reads a single value from the given reader and parses it as JsonValue.
parse(Reader, int) - Method in class com.hazelcast.internal.json.JsonReducedValueParser
Reads a single value from the given reader and parses it as JsonValue.
parse(Element) - Method in interface com.hazelcast.internal.services.ServiceConfigurationParser
 
parse(String) - Static method in class com.hazelcast.memory.MemorySize
Parses string representation of a memory size value.
parse(String, MemoryUnit) - Static method in class com.hazelcast.memory.MemorySize
Parses string representation of a memory size value.
parse(I) - Method in interface com.hazelcast.query.extractor.ArgumentParser
This method takes the unparsed argument object as an input and returns the parsed output that will be used by the ValueExtractor.
parse(Object) - Method in class com.hazelcast.query.impl.DefaultArgumentParser
 
parseClassFilterList(Node) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
parseClassNameFilters(UserCodeDeploymentConfig) - Static method in class com.hazelcast.internal.usercodedeployment.impl.filter.ClassNameFilterParser
 
parseDelimitedString(String, char) - Static method in class com.hazelcast.buildutils.ElementParser
 
parseDelimitedString(String, char, boolean) - Static method in class com.hazelcast.buildutils.ElementParser
Parses delimited string and returns an array containing the tokens.
ParseException - Exception in com.hazelcast.internal.json
An unchecked exception to indicate that an input does not qualify as valid JSON.
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.CacheManagerBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.HazelcastClientBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.HazelcastConfigBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.HazelcastFailoverClientBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.HazelcastInstanceDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.HazelcastTypeBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class com.hazelcast.spring.hibernate.RegionFactoryBeanDefinitionParser
 
parseListeners(Node, Class) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
parseMemberFilter(String) - Static method in class com.hazelcast.internal.usercodedeployment.impl.filter.MemberProviderFilterParser
 
parseMemcacheKey(String) - Static method in class com.hazelcast.internal.ascii.memcache.MemcacheUtils
Parse Memcache key into (MapName, Key) pair.
parseMetricName(String) - Static method in class com.hazelcast.internal.metrics.MetricsUtil
Parses metric name in tagged format into a list of tag-value tuples.
parseProperties(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
parseProxyFactories(Node, Class) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
parser(TextDecoder, String, int) - Method in interface com.hazelcast.internal.ascii.CommandParser
 
parser(TextDecoder, String, int, Connection) - Method in interface com.hazelcast.internal.ascii.CommandParser
 
parser(TextDecoder, String, int) - Method in class com.hazelcast.internal.ascii.memcache.DeleteCommandParser
 
parser(TextDecoder, String, int) - Method in class com.hazelcast.internal.ascii.memcache.GetCommandParser
 
parser(TextDecoder, String, int) - Method in class com.hazelcast.internal.ascii.memcache.IncrementCommandParser
 
parser(TextDecoder, String, int) - Method in class com.hazelcast.internal.ascii.memcache.SetCommandParser
 
parser(TextDecoder, String, int) - Method in class com.hazelcast.internal.ascii.memcache.SimpleCommandParser
 
parser(TextDecoder, String, int) - Method in class com.hazelcast.internal.ascii.memcache.TouchCommandParser
 
parser(TextDecoder, String, int) - Method in class com.hazelcast.internal.ascii.rest.HttpDeleteCommandParser
 
parser(TextDecoder, String, int) - Method in class com.hazelcast.internal.ascii.rest.HttpGetCommandParser
 
parser(TextDecoder, String, int) - Method in class com.hazelcast.internal.ascii.rest.HttpHeadCommandParser
 
parser(TextDecoder, String, int) - Method in class com.hazelcast.internal.ascii.rest.HttpPostCommandParser
 
parser(TextDecoder, String, int, Connection) - Method in class com.hazelcast.internal.ascii.rest.HttpPostCommandParser
 
parseSerialization(Node) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
parseSocketInterceptorConfig(Node) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
parseSslConfig(Node) - Method in class com.hazelcast.config.AbstractDomConfigProcessor
 
parseString(String) - Static method in enum com.hazelcast.config.CacheDeserializedValues
Create instance from String
parseValue(JsonReducedValueParser, int) - Method in class com.hazelcast.internal.serialization.impl.DataInputNavigableJsonAdapter
 
parseValue(JsonReducedValueParser, int) - Method in class com.hazelcast.internal.serialization.impl.NavigableJsonInputAdapter
Tries to parse a single JsonValue from the input.
parseValue(JsonReducedValueParser, int) - Method in class com.hazelcast.internal.serialization.impl.StringNavigableJsonAdapter
 
Partition - Interface in com.hazelcast.partition
In Hazelcast the data is split up in partitions: by default, 271 and configurable through the 'hazelcast.partition.count' GroupProperty.
PARTITION_BACKUP_REPLICA_ANTI_ENTROPY - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
PARTITION_BACKUP_SYNC_INTERVAL - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
PARTITION_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Total number of partitions in the Hazelcast cluster.
PARTITION_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
PARTITION_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
PARTITION_FRAGMENTED_MIGRATION_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
PARTITION_GROUP_HOST - Static variable in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
Metadata key definition for a low-latency link on a shared physical node, in case of virtualization being used
PARTITION_GROUP_RACK - Static variable in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
Metadata key definition for a low-latency link inside the same data center but for different racks
PARTITION_GROUP_ZONE - Static variable in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
Metadata key definition for a low-latency link between (virtual) data centers in the same area
PARTITION_HASH_OFFSET - Static variable in class com.hazelcast.internal.serialization.impl.HeapData
 
PARTITION_ID_FIELD_OFFSET - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
PARTITION_ITERATOR - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
PARTITION_LOST_EVENT - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
PARTITION_LOST_EVENT - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
 
PARTITION_LOST_EVENT_FILTER - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
PARTITION_LOST_EVENT_TOPIC - Static variable in interface com.hazelcast.internal.partition.InternalPartitionService
Static constant for dispatching and listening internal partition lost events
PARTITION_MAX_PARALLEL_REPLICATIONS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
PARTITION_MIGRATING - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
PARTITION_MIGRATION_INTERVAL - Static variable in class com.hazelcast.spi.properties.GroupProperty
Time in seconds to sleep after a migration task.
PARTITION_MIGRATION_TIMEOUT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Timeout in seconds for all migration operations.
PARTITION_OPERATION_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
The number of partition operation handler threads per member.
PARTITION_OPERATION_THREAD_ISOLATED - Static variable in class com.hazelcast.spi.properties.GroupProperty
PARTITION_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
PARTITION_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
PARTITION_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
PARTITION_REPLICA - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
PARTITION_RESPONSE - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
PARTITION_RUNTIME_STATE - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
PARTITION_STATE_OP - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
PARTITION_STATE_VERSION_CHECK_OP - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
PARTITION_STRATEGY_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
PARTITION_TABLE_SEND_INTERVAL - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
PARTITION_WIDE_ENTRY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
PARTITION_WIDE_ENTRY_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
PARTITION_WIDE_ENTRY_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
PARTITION_WIDE_PREDICATE_ENTRY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
PARTITION_WIDE_PREDICATE_ENTRY_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
PARTITION_WIDE_PREDICATE_ENTRY_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
PartitionAccumulatorRegistry - Class in com.hazelcast.map.impl.querycache.publisher
Registry of mappings like partitionId to Accumulator.
PartitionAccumulatorRegistry(AccumulatorInfo, ConstructorFunction<Integer, Accumulator>) - Constructor for class com.hazelcast.map.impl.querycache.publisher.PartitionAccumulatorRegistry
 
PartitionAware<T> - Interface in com.hazelcast.partition
PartitionAware means that data will be based in the same member based on the partition key and implementing tasks will be executed on the PartitionAware.getPartitionKey()'s owner member.
PartitionAwareFactoryAccessor - Class in com.hazelcast.spi.impl.operationservice.impl.operations
 
PartitionAwareKey<K,P> - Class in com.hazelcast.partition
PartitionAwareKey(K, P) - Constructor for class com.hazelcast.partition.PartitionAwareKey
Creates a new PartitionAwareKey.
PartitionAwareOperation - Interface in com.hazelcast.spi.impl.operationservice
An interface that can be implemented by an operation to indicate that it should be invoked on a particular partition.
PartitionAwareOperationFactory - Class in com.hazelcast.spi.impl.operationservice.impl.operations
Creates partition specific operations.
PartitionAwareOperationFactory() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionAwareOperationFactory
 
partitionAwareService - Variable in class com.hazelcast.map.impl.MapService
 
PartitionAwareService - Interface in com.hazelcast.spi.partition
An interface that can be implemented by SPI services to get notified of when a partition-related event occurs; for example, if a MapService notifies its map listeners when partition is lost for a map.
PartitionBackupReplicaAntiEntropyOperation - Class in com.hazelcast.internal.partition.operation
 
PartitionBackupReplicaAntiEntropyOperation() - Constructor for class com.hazelcast.internal.partition.operation.PartitionBackupReplicaAntiEntropyOperation
 
PartitionBackupReplicaAntiEntropyOperation(Map<ServiceNamespace, Long>, boolean) - Constructor for class com.hazelcast.internal.partition.operation.PartitionBackupReplicaAntiEntropyOperation
 
PartitionContainer - Class in com.hazelcast.map.impl
 
PartitionContainer(MapService, int) - Constructor for class com.hazelcast.map.impl.PartitionContainer
 
PartitionContainer - Class in com.hazelcast.replicatedmap.impl
Contains the record storage for the replicated maps which are the actual place where the data is stored.
PartitionContainer(ReplicatedMapService, int) - Constructor for class com.hazelcast.replicatedmap.impl.PartitionContainer
 
partitionCount - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
partitionCount - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
partitionCount - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec.RequestParameters
the expected partition count of the cluster.
partitionCount - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec.ResponseParameters
the expected partition count of the cluster.
partitionCount - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec.RequestParameters
the expected partition count of the cluster.
partitionCount - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec.ResponseParameters
the expected partition count of the cluster.
partitionCount - Variable in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
 
partitionCount - Variable in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
 
partitionCount - Variable in class com.hazelcast.map.impl.nearcache.MapNearCacheManager
 
PartitionDataSerializerHook - Class in com.hazelcast.internal.partition.impl
 
PartitionDataSerializerHook() - Constructor for class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
PartitionEvent - Interface in com.hazelcast.partition
PartitionEvent is a base interface for partition related events.
PartitionEventListener<T extends PartitionEvent> - Interface in com.hazelcast.internal.partition
PartitionEventListener is a base interface for partition-related event listeners.
PartitionEventManager - Class in com.hazelcast.internal.partition.impl
Maintains registration of partition-system related listeners and dispatches corresponding events.
PartitionEventManager(Node) - Constructor for class com.hazelcast.internal.partition.impl.PartitionEventManager
 
PartitionGroupConfig - Class in com.hazelcast.config
With PartitionGroupConfig, you can control how primary and backup partitions are mapped to physical Members.
PartitionGroupConfig() - Constructor for class com.hazelcast.config.PartitionGroupConfig
 
PartitionGroupConfig.MemberGroupType - Enum in com.hazelcast.config
Type of member groups.
PartitionGroupMetaData - Enum in com.hazelcast.spi.partitiongroup
This class contains the definition of known Discovery SPI metadata to support automatic generation of zone aware backup strategies based on cloud or service discovery provided information.
PartitionGroupStrategy - Interface in com.hazelcast.spi.partitiongroup
A PartitionGroupStrategy implementation defines a strategy how backup groups are designed.
partitionId - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
partitionId - Variable in class com.hazelcast.cache.impl.CachePartitionSegment
 
partitionId - Variable in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
partitionId - Variable in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
 
partitionId - Variable in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
 
partitionId - Variable in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxySupport
 
partitionId - Variable in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
partitionId - Variable in class com.hazelcast.internal.partition.impl.AbstractPartitionPrimaryReplicaAntiEntropyTask
 
partitionId - Variable in class com.hazelcast.map.impl.iterator.AbstractMapPartitionIterator
 
partitionId - Variable in class com.hazelcast.map.impl.iterator.AbstractMapQueryPartitionIterator
 
partitionId() - Method in class com.hazelcast.map.impl.query.Target
 
partitionId - Variable in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
partitionId - Variable in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
 
partitionId - Variable in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
 
PartitionIdSet - Class in com.hazelcast.internal.util.collection
A mutable set of partition IDs.
PartitionIdSet(int) - Constructor for class com.hazelcast.internal.util.collection.PartitionIdSet
 
PartitionIdSet(int, Collection<Integer>) - Constructor for class com.hazelcast.internal.util.collection.PartitionIdSet
 
PartitionIdSet(PartitionIdSet) - Constructor for class com.hazelcast.internal.util.collection.PartitionIdSet
 
partitionIndex - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
PartitionIndexesStats - Class in com.hazelcast.monitor.impl
The implementation of internal indexes stats specialized for partitioned indexes.
PartitionIndexesStats() - Constructor for class com.hazelcast.monitor.impl.PartitionIndexesStats
 
PartitionIndexOperationStats - Class in com.hazelcast.monitor.impl
The implementation of operation index stats specialized for partition indexes.
PartitionIndexOperationStats() - Constructor for class com.hazelcast.monitor.impl.PartitionIndexOperationStats
 
PARTITIONING_STRATEGY - Static variable in class com.hazelcast.spi.impl.AbstractDistributedObject
 
PARTITIONING_STRATEGY_CLASS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
partitioningStrategy - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
partitioningStrategy - Variable in class com.hazelcast.map.impl.MapContainer
 
PartitioningStrategy<K> - Interface in com.hazelcast.partition
PartitioningStrategy allows keys to be located on the same member.
partitioningStrategyClassName - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
name of class implementing com.hazelcast.core.PartitioningStrategy or null
PartitioningStrategyConfig - Class in com.hazelcast.config
Contains the configuration for partitioning strategy.
PartitioningStrategyConfig() - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
 
PartitioningStrategyConfig(PartitioningStrategyConfig) - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
 
PartitioningStrategyConfig(String) - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
 
PartitioningStrategyConfig(PartitioningStrategy) - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
 
PartitioningStrategyConfigReadOnly - Class in com.hazelcast.internal.config
Contains the configuration for strategy of partitioning
PartitioningStrategyConfigReadOnly(PartitioningStrategyConfig) - Constructor for class com.hazelcast.internal.config.PartitioningStrategyConfigReadOnly
 
PartitioningStrategyFactory - Class in com.hazelcast.map.impl
Factory for PartitioningStrategy instances.
PartitioningStrategyFactory(ClassLoader) - Constructor for class com.hazelcast.map.impl.PartitioningStrategyFactory
Construct a new PartitioningStrategyFactory
partitioningStrategyImplementation - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
a serialized instance of a partitioning strategy
PartitionIteratingOperation - Class in com.hazelcast.spi.impl.operationservice.impl.operations
Executes Operations on one or more partitions.
PartitionIteratingOperation() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation
 
PartitionIteratingOperation(OperationFactory, int[]) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation
 
PartitionIteratingOperation.PartitionResponse - Class in com.hazelcast.spi.impl.operationservice.impl.operations
 
partitionLost(CachePartitionLostEvent) - Method in interface com.hazelcast.cache.impl.event.CachePartitionLostListener
Invoked when owner and all backups of a partition are lost for a specific cache.
partitionLost(PartitionLostEvent) - Method in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
This method increments a counter to count partition lost events.
partitionLost(PartitionLostEvent) - Method in class com.hazelcast.internal.eviction.ExpirationManager
 
partitionLost(MapPartitionLostEvent) - Method in interface com.hazelcast.map.listener.MapPartitionLostListener
Invoked when owner and all backups of a partition is lost for a specific map.
partitionLost(PartitionLostEvent) - Method in interface com.hazelcast.partition.PartitionLostListener
Invoked when a partition loses its owner and all backups.
PartitionLostEvent - Interface in com.hazelcast.partition
The event that is fired when a partition lost its owner and all backups.
PartitionLostEventImpl - Class in com.hazelcast.internal.partition
The event that is fired when a partition lost its owner and all backups.
PartitionLostEventImpl() - Constructor for class com.hazelcast.internal.partition.PartitionLostEventImpl
 
PartitionLostEventImpl(int, int, Address) - Constructor for class com.hazelcast.internal.partition.PartitionLostEventImpl
 
PartitionLostListener - Interface in com.hazelcast.partition
PartitionLostListener provides the ability to be notified upon a possible data loss when a partition loses a replica.
partitionLostListenerConfigs - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
partition lost listener configurations
partitionLostListenerConfigs - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
partition lost listener configurations
PartitionMigratingException - Exception in com.hazelcast.spi.exception
A RetryableHazelcastException that is thrown when an operation is executed on a partition, but that partition is currently being moved around.
PartitionMigratingException(Address, int, String, String) - Constructor for exception com.hazelcast.spi.exception.PartitionMigratingException
 
PartitionMigratingException(String) - Constructor for exception com.hazelcast.spi.exception.PartitionMigratingException
 
PartitionMigrationEvent - Class in com.hazelcast.spi.partition
An EventObject for a partition migration.
PartitionMigrationEvent(MigrationEndpoint, int, int, int) - Constructor for class com.hazelcast.spi.partition.PartitionMigrationEvent
 
PartitionOperationThread - Class in com.hazelcast.spi.impl.operationexecutor.impl
An OperationThread that executes Operations for a particular partition, e.g.
PartitionOperationThread(String, int, OperationQueue, ILogger, NodeExtension, OperationRunner[], ClassLoader) - Constructor for class com.hazelcast.spi.impl.operationexecutor.impl.PartitionOperationThread
 
PartitionPerIndexStats - Class in com.hazelcast.monitor.impl
The implementation of internal index stats specialized for partitioned indexes.
PartitionPerIndexStats() - Constructor for class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
PartitionPortableHook - Class in com.hazelcast.internal.partition.impl
 
PartitionPortableHook() - Constructor for class com.hazelcast.internal.partition.impl.PartitionPortableHook
 
PartitionPredicate<K,V> - Interface in com.hazelcast.query
A Predicate that restricts the execution of a Predicate to a single Partition.
partitionPredicate(Object, Predicate<K, V>) - Static method in class com.hazelcast.query.Predicates
Creates a new partition predicate that restricts the execution of the target predicate to a single partition.
PartitionPredicateImpl<K,V> - Class in com.hazelcast.query.impl.predicates
Implementation of PartitionPredicate.
PartitionPredicateImpl() - Constructor for class com.hazelcast.query.impl.predicates.PartitionPredicateImpl
 
PartitionPredicateImpl(Object, Predicate<K, V>) - Constructor for class com.hazelcast.query.impl.predicates.PartitionPredicateImpl
Creates a new PartitionPredicate.
PartitionQueryContextProvider - Class in com.hazelcast.query.impl
Provides the query context support for partitioned indexes with disabled stats.
PartitionQueryContextProvider(Indexes) - Constructor for class com.hazelcast.query.impl.PartitionQueryContextProvider
Constructs a new partition query context provider for the given indexes.
PartitionQueryContextProviderWithStats - Class in com.hazelcast.query.impl
Provides the query context support for partitioned indexes with enabled stats.
PartitionQueryContextProviderWithStats(Indexes) - Constructor for class com.hazelcast.query.impl.PartitionQueryContextProviderWithStats
Constructs a new partition query context provider with stats for the given indexes.
PartitionQueryContextWithStats - Class in com.hazelcast.query.impl
Extends the basic query context to support the per-index stats tracking on behalf of partitioned indexes.
PartitionQueryContextWithStats(Indexes) - Constructor for class com.hazelcast.query.impl.PartitionQueryContextWithStats
Constructs a new partition query context with stats for the given indexes.
PartitionReplica - Class in com.hazelcast.internal.partition
PartitionReplica represents owner of a partition replica in the partition table.
PartitionReplica() - Constructor for class com.hazelcast.internal.partition.PartitionReplica
 
PartitionReplica(Address, UUID) - Constructor for class com.hazelcast.internal.partition.PartitionReplica
 
PartitionReplicaInterceptor - Interface in com.hazelcast.internal.partition
Interceptor for partition replica changes.
PartitionReplicaManager - Class in com.hazelcast.internal.partition.impl
Maintains the version values for the partition replicas and manages the replica-related operations for partitions
PartitionReplicaStateChecker - Class in com.hazelcast.internal.partition.impl
Verifies up-to-dateness of each of partition replicas owned by this member.
PartitionReplicaSyncRequest - Class in com.hazelcast.internal.partition.operation
The request sent from a replica to the partition owner to synchronize the replica data.
PartitionReplicaSyncRequest() - Constructor for class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRequest
 
PartitionReplicaSyncRequest(int, List<ServiceNamespace>, int) - Constructor for class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRequest
 
PartitionReplicaSyncResponse - Class in com.hazelcast.internal.partition.operation
The replica synchronization response sent from the partition owner to a replica.
PartitionReplicaSyncResponse() - Constructor for class com.hazelcast.internal.partition.operation.PartitionReplicaSyncResponse
 
PartitionReplicaSyncResponse(Collection<Operation>, ServiceNamespace, long[]) - Constructor for class com.hazelcast.internal.partition.operation.PartitionReplicaSyncResponse
 
PartitionReplicaSyncRetryResponse - Class in com.hazelcast.internal.partition.operation
The response to a PartitionReplicaSyncRequest that the replica should retry.
PartitionReplicaSyncRetryResponse() - Constructor for class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRetryResponse
 
PartitionReplicaSyncRetryResponse(Collection<ServiceNamespace>) - Constructor for class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRetryResponse
 
PartitionReplicationEvent - Class in com.hazelcast.spi.partition
An event send to MigrationAwareService when partition changes happen.
PartitionReplicationEvent(int, int) - Constructor for class com.hazelcast.spi.partition.PartitionReplicationEvent
Creates a PartitionReplicationEvent
PartitionReplicaVersionManager - Interface in com.hazelcast.internal.partition
PartitionReplicaVersionManager maintains partition replica version handling.
PartitionResponse() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation.PartitionResponse
 
PartitionRuntimeState - Class in com.hazelcast.internal.partition
 
PartitionRuntimeState() - Constructor for class com.hazelcast.internal.partition.PartitionRuntimeState
 
PartitionRuntimeState(InternalPartition[], Collection<MigrationInfo>, int) - Constructor for class com.hazelcast.internal.partition.PartitionRuntimeState
 
partitions - Variable in class com.hazelcast.client.impl.protocol.codec.ClientGetPartitionsCodec.ResponseParameters
TODO DOC
partitions - Variable in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionAwareOperationFactory
Partition-operations will be created for these partition IDs.
PartitionScanExecutor - Interface in com.hazelcast.map.impl.query
Responsible for executing a full partition scan for the given partitions.
partitionScanExecutor - Variable in class com.hazelcast.map.impl.query.QueryRunner
 
PartitionScanRunner - Class in com.hazelcast.map.impl.query
Responsible for running a full-partition scan for a single partition in the calling thread.
PartitionScanRunner(MapServiceContext) - Constructor for class com.hazelcast.map.impl.query.PartitionScanRunner
 
PartitionSequencer - Interface in com.hazelcast.map.impl.querycache.event.sequence
General contract of a sequence-number provider for a partition.
partitionService - Variable in class com.hazelcast.client.impl.spi.impl.AbstractClientInvocationService
 
partitionService - Variable in class com.hazelcast.collection.impl.collection.CollectionService
 
partitionService - Variable in class com.hazelcast.instance.impl.Node
 
partitionService - Variable in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
partitionService - Variable in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
 
partitionService - Variable in class com.hazelcast.internal.partition.impl.AbstractPartitionPrimaryReplicaAntiEntropyTask
 
partitionService - Variable in class com.hazelcast.map.impl.event.MapEventPublisherImpl
 
partitionService - Variable in class com.hazelcast.map.impl.eviction.EvictorImpl
 
partitionService - Variable in class com.hazelcast.map.impl.nearcache.MapNearCacheManager
 
partitionService - Variable in class com.hazelcast.map.impl.query.PartitionScanRunner
 
partitionService - Variable in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
 
PartitionService - Interface in com.hazelcast.partition
PartitionService allows you to query Partitions and attach/detach MigrationListeners to listen to partition migration events.
partitionService - Variable in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
PartitionServiceBeanDTO - Class in com.hazelcast.internal.management.dto
A Serializable DTO for PartitionServiceMBean.
PartitionServiceBeanDTO() - Constructor for class com.hazelcast.internal.management.dto.PartitionServiceBeanDTO
 
PartitionServiceBeanDTO(InternalPartitionService, HazelcastInstanceImpl) - Constructor for class com.hazelcast.internal.management.dto.PartitionServiceBeanDTO
 
PartitionServiceMBean - Class in com.hazelcast.internal.jmx
Management bean for PartitionService
PartitionServiceMBean(HazelcastInstanceImpl, InternalPartitionService, ManagementService) - Constructor for class com.hazelcast.internal.jmx.PartitionServiceMBean
 
PartitionServiceProxy - Class in com.hazelcast.client.impl.proxy
 
PartitionServiceProxy(ClientPartitionService, ClientListenerService) - Constructor for class com.hazelcast.client.impl.proxy.PartitionServiceProxy
 
PartitionServiceProxy - Class in com.hazelcast.internal.partition
 
PartitionServiceProxy(NodeEngineImpl, InternalPartitionServiceImpl) - Constructor for class com.hazelcast.internal.partition.PartitionServiceProxy
 
PartitionServiceState - Enum in com.hazelcast.internal.partition.impl
Represents partition service state of current member.
PartitionSpecificRunnable - Interface in com.hazelcast.spi.impl
A Runnable for a specific partition.
PartitionSpecificRunnableAdaptor - Class in com.hazelcast.cp.internal.util
A PartitionSpecificRunnable implementation which wraps a plain Runnable
PartitionSpecificRunnableAdaptor(Runnable, int) - Constructor for class com.hazelcast.cp.internal.util.PartitionSpecificRunnableAdaptor
 
PartitionStateGenerator - Interface in com.hazelcast.internal.partition
 
PartitionStateManager - Class in com.hazelcast.internal.partition.impl
Maintains the partition table state.
PartitionStateManager(Node, InternalPartitionServiceImpl) - Constructor for class com.hazelcast.internal.partition.impl.PartitionStateManager
 
PartitionStateOperation - Class in com.hazelcast.internal.partition.operation
Sent from the master to publish or sync the partition table state to all cluster members.
PartitionStateOperation() - Constructor for class com.hazelcast.internal.partition.operation.PartitionStateOperation
 
PartitionStateOperation(PartitionRuntimeState, boolean) - Constructor for class com.hazelcast.internal.partition.operation.PartitionStateOperation
 
partitionStateVersion - Variable in class com.hazelcast.client.impl.protocol.codec.ClientGetPartitionsCodec.ResponseParameters
TODO DOC
PartitionStateVersionCheckOperation - Class in com.hazelcast.internal.partition.operation
Sent from the master to check the partition table state version on target member.
PartitionStateVersionCheckOperation() - Constructor for class com.hazelcast.internal.partition.operation.PartitionStateVersionCheckOperation
 
PartitionStateVersionCheckOperation(int) - Constructor for class com.hazelcast.internal.partition.operation.PartitionStateVersionCheckOperation
 
PartitionStateVersionMismatchException - Exception in com.hazelcast.internal.partition
Thrown when local partition-state version doesn't match the version of master member while running a migration/replication operation.
PartitionStateVersionMismatchException(String) - Constructor for exception com.hazelcast.internal.partition.PartitionStateVersionMismatchException
 
PartitionStateVersionMismatchException(int, int) - Constructor for exception com.hazelcast.internal.partition.PartitionStateVersionMismatchException
 
partitionStrategy - Variable in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
 
PartitionTableView - Class in com.hazelcast.internal.partition
An immutable/readonly view of partition table.
PartitionTableView(PartitionReplica[][], int) - Constructor for class com.hazelcast.internal.partition.PartitionTableView
 
PartitionTableView(InternalPartition[], int) - Constructor for class com.hazelcast.internal.partition.PartitionTableView
 
PartitionTaskFactory<T> - Interface in com.hazelcast.spi.impl.operationservice
An factory for creating partition specific tasks.
partitionUuid - Variable in class com.hazelcast.map.impl.operation.MapNearCacheStateHolder
 
partitionUuidList - Variable in class com.hazelcast.client.impl.protocol.codec.CacheAssignAndGetUuidsCodec.ResponseParameters
partitionId to assigned uuid entry list
partitionUuidList - Variable in class com.hazelcast.client.impl.protocol.codec.CacheFetchNearCacheInvalidationMetadataCodec.ResponseParameters
TODO DOC
partitionUuidList - Variable in class com.hazelcast.client.impl.protocol.codec.MapAssignAndGetUuidsCodec.ResponseParameters
partitionId to assigned uuid entry list
partitionUuidList - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchNearCacheInvalidationMetadataCodec.ResponseParameters
TODO DOC
PartitionWideEntryBackupOperation - Class in com.hazelcast.map.impl.operation
 
PartitionWideEntryBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryBackupOperation
 
PartitionWideEntryBackupOperation(String, EntryProcessor) - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryBackupOperation
 
PartitionWideEntryOperation - Class in com.hazelcast.map.impl.operation
GOTCHA: This operation does NOT load missing keys from map-store for now.
PartitionWideEntryOperation() - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
 
PartitionWideEntryOperation(String, EntryProcessor) - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
 
PartitionWideEntryOperationFactory - Class in com.hazelcast.map.impl.operation
 
PartitionWideEntryOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryOperationFactory
 
PartitionWideEntryOperationFactory(String, EntryProcessor) - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryOperationFactory
 
PartitionWideEntryWithPredicateBackupOperation - Class in com.hazelcast.map.impl.operation
 
PartitionWideEntryWithPredicateBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateBackupOperation
 
PartitionWideEntryWithPredicateBackupOperation(String, EntryProcessor, Predicate) - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateBackupOperation
 
PartitionWideEntryWithPredicateOperation - Class in com.hazelcast.map.impl.operation
 
PartitionWideEntryWithPredicateOperation() - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperation
 
PartitionWideEntryWithPredicateOperation(String, EntryProcessor, Predicate) - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperation
 
PartitionWideEntryWithPredicateOperationFactory - Class in com.hazelcast.map.impl.operation
 
PartitionWideEntryWithPredicateOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperationFactory
 
PartitionWideEntryWithPredicateOperationFactory(String, EntryProcessor, Predicate) - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperationFactory
 
PASS_THROUGH - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
PassThroughMergePolicy<V,T extends MergingValue<V>> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination directly unless the merging entry is null.
PassThroughMergePolicy() - Constructor for class com.hazelcast.spi.merge.PassThroughMergePolicy
 
password - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec.RequestParameters
Password for the user.
PasswordCredentials - Interface in com.hazelcast.security
Credentials type for name/password representation.
path() - Method in class com.hazelcast.internal.yaml.AbstractYamlNode
 
path() - Method in interface com.hazelcast.internal.yaml.YamlNode
Returns the path of the node from the root of the YAML structure.
pause(String, String) - Method in interface com.hazelcast.wan.impl.WanReplicationService
Pauses WAN replication for the given wanReplicationName and wanPublisherId on this hazelcast instance.
pause(String, String) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
 
pause() - Method in interface com.hazelcast.wan.WanReplicationPublisher
Calls to this method will pause WAN event container polling.
pauseMigration() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
pauseMigration() - Method in interface com.hazelcast.internal.partition.InternalPartitionService
Pause all migrations
payload - Variable in class com.hazelcast.internal.serialization.impl.HeapData
 
peek() - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
peek() - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnQueueProxy
 
peek(long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnQueueProxy
 
peek() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Retrieves, but does not remove, the head of this queue, or returns null if this queue is empty.
PEEK - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
peek() - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
peek() - Method in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxy
 
peek(long, TimeUnit) - Method in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxy
 
peek() - Method in class com.hazelcast.internal.util.concurrent.MPSCQueue
 
peek() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
Retrieves, but does not remove, the head of this queue, or returns null if this queue is empty.
peek() - Method in interface com.hazelcast.transaction.TransactionalQueue
peek(long, TimeUnit) - Method in interface com.hazelcast.transaction.TransactionalQueue
peekNext() - Method in class com.hazelcast.client.impl.protocol.ClientMessage.ForwardFrameIterator
 
peekNextTailSequence() - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
 
peekNextTailSequence() - Method in interface com.hazelcast.ringbuffer.impl.Ringbuffer
Returns the next sequence which the tail will be at after the next item is added.
PeekOperation - Class in com.hazelcast.collection.impl.queue.operations
Peek operation for Queue.
PeekOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.PeekOperation
 
PeekOperation(String) - Constructor for class com.hazelcast.collection.impl.queue.operations.PeekOperation
 
peel(Throwable) - Static method in class com.hazelcast.internal.util.ExceptionUtil
 
peel(Throwable, Class<T>, String) - Static method in class com.hazelcast.internal.util.ExceptionUtil
Processes Throwable t so that the returned Throwable's type matches allowedType or RuntimeException.
peel(Throwable, Class<T>, String, ExceptionUtil.RuntimeExceptionFactory) - Static method in class com.hazelcast.internal.util.ExceptionUtil
Processes Throwable t so that the returned Throwable's type matches allowedType or RuntimeException.
peelIfNeeded(Throwable) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
peelIfNeeded(Throwable) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromAddressMessageTask
Exceptions may be wrapped in ExecutionExceptionDecorator, the wrapped ExecutionException should be sent to the client.
peelIfNeeded(Throwable) - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromPartitionMessageTask
Exceptions may be wrapped in ExecutionExceptionDecorator, the wrapped ExecutionException should be sent to the client.
PendingInvocationsPlugin - Class in com.hazelcast.internal.diagnostics
A DiagnosticsPlugin that aggregates the pending invocation so that per type of operation, the occurrence count is displayed.
PendingInvocationsPlugin(NodeEngineImpl) - Constructor for class com.hazelcast.internal.diagnostics.PendingInvocationsPlugin
 
PerIndexStats - Interface in com.hazelcast.monitor.impl
Provides internal per-index statistics for Index.
PERIOD_SECONDS - Static variable in class com.hazelcast.client.impl.statistics.Statistics
The period in seconds the statistics run.
PERIOD_SECONDS - Static variable in class com.hazelcast.internal.diagnostics.EventQueuePlugin
The period in seconds this plugin runs.
PERIOD_SECONDS - Static variable in class com.hazelcast.internal.diagnostics.MemberHazelcastInstanceInfoPlugin
The period in seconds the HazelcastMemberInstanceInfoPlugin runs.
PERIOD_SECONDS - Static variable in class com.hazelcast.internal.diagnostics.MemberHeartbeatPlugin
The period in seconds the MemberHeartbeatPlugin runs.
PERIOD_SECONDS - Static variable in class com.hazelcast.internal.diagnostics.MetricsPlugin
The period in seconds the MetricsPlugin runs.
PERIOD_SECONDS - Static variable in class com.hazelcast.internal.diagnostics.NetworkingImbalancePlugin
The period in seconds this plugin runs.
PERIOD_SECONDS - Static variable in class com.hazelcast.internal.diagnostics.OperationHeartbeatPlugin
The period in seconds this plugin runs.
PERIOD_SECONDS - Static variable in class com.hazelcast.internal.diagnostics.OperationThreadSamplerPlugin
The sample period in seconds.
PERIOD_SECONDS - Static variable in class com.hazelcast.internal.diagnostics.OverloadedConnectionsPlugin
The period in seconds this plugin runs.
PERIOD_SECONDS - Static variable in class com.hazelcast.internal.diagnostics.PendingInvocationsPlugin
The period in seconds this plugin runs.
PERIOD_SECONDS - Static variable in class com.hazelcast.internal.diagnostics.SlowOperationPlugin
The period in seconds the SlowOperationPlugin runs.
PERIOD_SECONDS - Static variable in class com.hazelcast.internal.diagnostics.StoreLatencyPlugin
The period in seconds this plugin runs.
periodInMillis - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToAddressCodec.RequestParameters
period between each run in milliseconds
periodInMillis - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToPartitionCodec.RequestParameters
period between each run in milliseconds
PERMISSION_CONFIG_DTO - Static variable in class com.hazelcast.internal.management.ManagementDataSerializerHook
 
PermissionConfig - Class in com.hazelcast.config
Contains the configuration for a permission.
PermissionConfig() - Constructor for class com.hazelcast.config.PermissionConfig
 
PermissionConfig(PermissionConfig.PermissionType, String, String) - Constructor for class com.hazelcast.config.PermissionConfig
 
PermissionConfig(PermissionConfig) - Constructor for class com.hazelcast.config.PermissionConfig
 
PermissionConfig.PermissionType - Enum in com.hazelcast.config
Type of permission
PermissionConfigDTO - Class in com.hazelcast.internal.management.dto
DTO object that provides serialization/deserialization support for PermissionConfig
PermissionConfigDTO() - Constructor for class com.hazelcast.internal.management.dto.PermissionConfigDTO
 
PermissionConfigDTO(PermissionConfig) - Constructor for class com.hazelcast.internal.management.dto.PermissionConfigDTO
 
PermissionPolicyConfig - Class in com.hazelcast.config
Contains the configuration for policy of permission
PermissionPolicyConfig() - Constructor for class com.hazelcast.config.PermissionPolicyConfig
 
PermissionPolicyConfig(String) - Constructor for class com.hazelcast.config.PermissionPolicyConfig
 
permits - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreAcquireCodec.RequestParameters
number of permits to acquire
permits - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreChangeCodec.RequestParameters
number of permits to increase / decrease
permits - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreInitCodec.RequestParameters
Number of permits to initialize this ISemaphore
permits - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreReleaseCodec.RequestParameters
number of permits to release
permits() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.AcquireInvocationKey
 
permits() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.AcquireResult
 
persistEntry(LogEntry) - Method in class com.hazelcast.cp.internal.raft.impl.persistence.NopRaftStateStore
 
persistEntry(LogEntry) - Method in interface com.hazelcast.cp.internal.raft.impl.persistence.RaftStateStore
Persists the given log entry.
persistInitialMembers(RaftEndpoint, Collection<RaftEndpoint>) - Method in class com.hazelcast.cp.internal.raft.impl.persistence.NopRaftStateStore
 
persistInitialMembers(RaftEndpoint, Collection<RaftEndpoint>) - Method in interface com.hazelcast.cp.internal.raft.impl.persistence.RaftStateStore
Persists the given local Raft endpoint and initial Raft group members.
persistLocalCPMember(CPMember) - Method in interface com.hazelcast.cp.internal.persistence.CPMetadataStore
Persists CPMember identity of the local member to storage.
persistLocalCPMember(CPMember) - Method in class com.hazelcast.cp.internal.persistence.NopCPMetadataStore
 
persistMetadataGroupId(RaftGroupId) - Method in interface com.hazelcast.cp.internal.persistence.CPMetadataStore
Persists group id of the METADATA group.
persistMetadataGroupId(RaftGroupId) - Method in class com.hazelcast.cp.internal.persistence.NopCPMetadataStore
 
persistSnapshot(SnapshotEntry) - Method in class com.hazelcast.cp.internal.raft.impl.persistence.NopRaftStateStore
 
persistSnapshot(SnapshotEntry) - Method in interface com.hazelcast.cp.internal.raft.impl.persistence.RaftStateStore
Persists the given snapshot entry.
persistTerm(int, RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.persistence.NopRaftStateStore
 
persistTerm(int, RaftEndpoint) - Method in interface com.hazelcast.cp.internal.raft.impl.persistence.RaftStateStore
Persists the term and the Raft endpoint that the local node voted for in the given term.
persistVote(int, RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Persist a vote for the endpoint in current term during leader election.
persistWanReplicatedData - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
PhiAccrualClusterFailureDetector - Class in com.hazelcast.internal.cluster.fd
Cluster failure detector based on 'The Phi Accrual Failure Detector' by Hayashibara et al.
PhiAccrualClusterFailureDetector(long, long, HazelcastProperties) - Constructor for class com.hazelcast.internal.cluster.fd.PhiAccrualClusterFailureDetector
 
PhiAccrualClusterFailureDetector(long, long, double, int, long) - Constructor for class com.hazelcast.internal.cluster.fd.PhiAccrualClusterFailureDetector
 
PhiAccrualFailureDetector - Class in com.hazelcast.internal.cluster.fd
Port of Akka's PhiAccrualFailureDetector.scala
PhiAccrualFailureDetector(double, int, double, long, long) - Constructor for class com.hazelcast.internal.cluster.fd.PhiAccrualFailureDetector
 
PHONE_HOME_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
phoneHome - Variable in class com.hazelcast.instance.impl.DefaultNodeExtension
 
PhoneHome - Class in com.hazelcast.internal.util
Pings phone home server with cluster info daily.
PhoneHome(Node) - Constructor for class com.hazelcast.internal.util.PhoneHome
 
phoneHome(Node, boolean) - Method in class com.hazelcast.internal.util.PhoneHome
Performs a phone request for node and returns the generated request parameters.
PhoneHome.PhoneHomeParameterCreator - Class in com.hazelcast.internal.util
Util class for parameters of OS and EE PhoneHome pings.
PhoneHomeParameterCreator() - Constructor for class com.hazelcast.internal.util.PhoneHome.PhoneHomeParameterCreator
 
pickAddress() - Method in interface com.hazelcast.instance.AddressPicker
Picks both server socket listener address and public address.
PingAware - Interface in com.hazelcast.splitbrainprotection
Split brain protection functions that need access to ICMP ping failure detector should implement this interface; the instance of PingFailureDetector used by this member's ClusterHeartbeatManager will be provided on initialization.
PingFailureDetector<E> - Class in com.hazelcast.internal.cluster.fd
Ping based failure detector.
PingFailureDetector(int) - Constructor for class com.hazelcast.internal.cluster.fd.PingFailureDetector
 
PingMessageTask - Class in com.hazelcast.client.impl.protocol.task
 
PingMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.PingMessageTask
 
Pipe<E> - Interface in com.hazelcast.internal.util.concurrent
A container of items processed in sequence.
Pipelining<E> - Class in com.hazelcast.core
The Pipelining can be used to speed up requests.
Pipelining(int) - Constructor for class com.hazelcast.core.Pipelining
Creates a Pipelining with the given depth.
PlaceHolder - Class in com.hazelcast
 
PlaceHolder() - Constructor for class com.hazelcast.PlaceHolder
 
PlatformSpecific - Class in com.hazelcast.internal
Utility class to construct instances depending on the runtime platform.
PN_COUNTER - Static variable in class com.hazelcast.internal.crdt.CRDTDataSerializerHook
The (de)serialization constant for a PNCounter implementation
PN_COUNTER_ADD_OPERATION - Static variable in class com.hazelcast.internal.crdt.CRDTDataSerializerHook
The constant for the PNCounter AddOperation
PN_COUNTER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
PN_COUNTER_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
PN_COUNTER_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
PN_COUNTER_GET_OPERATION - Static variable in class com.hazelcast.internal.crdt.CRDTDataSerializerHook
The constant for the PNCounter GetOperation
PN_COUNTER_REPLICATION - Static variable in class com.hazelcast.internal.crdt.CRDTDataSerializerHook
The (de)serialization constant for a PNCounter replication operation
PNCounter - Interface in com.hazelcast.crdt.pncounter
PN (Positive-Negative) CRDT counter.
PNCounterAddCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a delta to the PNCounter value.
PNCounterAddCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
PNCounterAddCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
PNCounterAddMessageTask - Class in com.hazelcast.client.impl.protocol.task.crdt.pncounter
Task responsible for processing client messages for updating the PNCounter state.
PNCounterAddMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterAddMessageTask
 
PNCounterConfig - Class in com.hazelcast.config
Configuration for a PNCounter
PNCounterConfig() - Constructor for class com.hazelcast.config.PNCounterConfig
 
PNCounterConfig(String, int, String, boolean) - Constructor for class com.hazelcast.config.PNCounterConfig
 
PNCounterConfig(String) - Constructor for class com.hazelcast.config.PNCounterConfig
 
PNCounterConfig(PNCounterConfig) - Constructor for class com.hazelcast.config.PNCounterConfig
 
PNCounterConfigReadOnly - Class in com.hazelcast.internal.config
 
PNCounterConfigReadOnly(PNCounterConfig) - Constructor for class com.hazelcast.internal.config.PNCounterConfigReadOnly
 
PNCounterGetCodec - Class in com.hazelcast.client.impl.protocol.codec
Query operation to retrieve the current value of the PNCounter.
PNCounterGetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
PNCounterGetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
PNCounterGetConfiguredReplicaCountCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the configured number of CRDT replicas for the PN counter with the given name.
PNCounterGetConfiguredReplicaCountCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
PNCounterGetConfiguredReplicaCountCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
PNCounterGetConfiguredReplicaCountMessageTask - Class in com.hazelcast.client.impl.protocol.task.crdt.pncounter
Task responsible for processing client messages for returning the max configured replica count for a PNCounter.
PNCounterGetConfiguredReplicaCountMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetConfiguredReplicaCountMessageTask
 
PNCounterGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.crdt.pncounter
Task responsible for processing client messages for retrieving the current PNCounter state.
PNCounterGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetMessageTask
 
PNCounterImpl - Class in com.hazelcast.internal.crdt.pncounter
PN (Positive-Negative) CRDT counter where each replica is identified by a String.
PNCounterImpl() - Constructor for class com.hazelcast.internal.crdt.pncounter.PNCounterImpl
 
PNCounterPermission - Class in com.hazelcast.security.permission
 
PNCounterPermission(String, String...) - Constructor for class com.hazelcast.security.permission.PNCounterPermission
 
PNCounterProxy - Class in com.hazelcast.internal.crdt.pncounter
Member proxy implementation for a PNCounter.
PNCounterReplicationOperation - Class in com.hazelcast.internal.crdt.pncounter
CRDT replication operation for a PNCounter.
PNCounterReplicationOperation() - Constructor for class com.hazelcast.internal.crdt.pncounter.PNCounterReplicationOperation
 
PNCounterService - Class in com.hazelcast.internal.crdt.pncounter
Service responsible for PNCounter proxies and replication operation.
PNCounterService() - Constructor for class com.hazelcast.internal.crdt.pncounter.PNCounterService
 
poll(long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
poll() - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
poll() - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnQueueProxy
 
poll(long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnQueueProxy
 
poll() - Method in interface com.hazelcast.collection.BaseQueue
Retrieves and removes the head of this queue, or returns null if this queue is empty.
poll(long, TimeUnit) - Method in interface com.hazelcast.collection.BaseQueue
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
poll() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Retrieves and removes the head of the queue (in other words, the first item), or returns null if it is empty.
POLL - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
poll(long, TimeUnit) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
poll() - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
poll() - Method in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxy
 
poll(long, TimeUnit) - Method in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxy
 
poll() - Method in interface com.hazelcast.collection.IQueue
Retrieves and removes the head of this queue, or returns null if this queue is empty.
poll(long, TimeUnit) - Method in interface com.hazelcast.collection.IQueue
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
poll(String, int) - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
poll(String) - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
poll(String, int) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
poll(String) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
poll() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationQueue
 
poll() - Method in class com.hazelcast.internal.util.concurrent.ManyToOneConcurrentArrayQueue
 
poll() - Method in class com.hazelcast.internal.util.concurrent.MPSCQueue
 
poll(long, TimeUnit) - Method in class com.hazelcast.internal.util.concurrent.MPSCQueue
 
poll() - Method in class com.hazelcast.internal.util.concurrent.OneToOneConcurrentArrayQueue
 
poll(AccumulatorHandler<E>, int) - Method in interface com.hazelcast.map.impl.querycache.accumulator.Accumulator
Reads this accumulator if it contains at least maxItems, otherwise do not read anything.
poll(AccumulatorHandler<E>, long, TimeUnit) - Method in interface com.hazelcast.map.impl.querycache.accumulator.Accumulator
Reads all expired items to the supplied handler.
poll(AccumulatorHandler<E>, int) - Method in class com.hazelcast.map.impl.querycache.accumulator.BasicAccumulator
 
poll(AccumulatorHandler<E>, long, TimeUnit) - Method in class com.hazelcast.map.impl.querycache.accumulator.BasicAccumulator
 
poll() - Method in interface com.hazelcast.transaction.TransactionalQueue
Retrieves and removes the head of this queue, or returns null if this queue is empty.
poll(long, TimeUnit) - Method in interface com.hazelcast.transaction.TransactionalQueue
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
POLL_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
pollBackup(long) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Polls an item on the backup replica.
PollBackupOperation - Class in com.hazelcast.collection.impl.queue.operations
Backup items during pool operation.
PollBackupOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.PollBackupOperation
 
PollBackupOperation(String, long) - Constructor for class com.hazelcast.collection.impl.queue.operations.PollBackupOperation
 
PollOperation - Class in com.hazelcast.collection.impl.queue.operations
Pool operation for Queue.
PollOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.PollOperation
 
PollOperation(String, long) - Constructor for class com.hazelcast.collection.impl.queue.operations.PollOperation
 
PoolExecutorThreadFactory - Class in com.hazelcast.internal.util.executor
 
PoolExecutorThreadFactory(String, ClassLoader) - Constructor for class com.hazelcast.internal.util.executor.PoolExecutorThreadFactory
 
PoolExecutorThreadFactory.ManagedThread - Class in com.hazelcast.internal.util.executor
 
poolSize - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddDurableExecutorConfigCodec.RequestParameters
executor thread pool size
poolSize - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddExecutorConfigCodec.RequestParameters
executor thread pool size
poolSize - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddScheduledExecutorConfigCodec.RequestParameters
number of executor threads per member for the executor
poolSize() - Method in class com.hazelcast.internal.jmx.ManagedExecutorServiceMBean
 
poolSize - Variable in class com.hazelcast.internal.management.dto.ManagedExecutorDTO
 
populate - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateCodec.RequestParameters
Flag to enable/disable initial population of the QueryCache.
populate - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateWithValueCodec.RequestParameters
Flag to enable/disable initial population of the QueryCache.
populate(LiveOperations) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
populate(LiveOperations) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
populate(LiveOperations) - Method in class com.hazelcast.internal.metrics.impl.LiveOperationRegistry
 
populate(LiveOperations) - Method in class com.hazelcast.internal.metrics.impl.MetricsService
 
populate(LiveOperations) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
populate(LiveOperations) - Method in class com.hazelcast.spi.impl.operationparker.impl.OperationParkerImpl
 
populate(LiveOperations) - Method in class com.hazelcast.spi.impl.operationparker.impl.WaitSet
 
populate(LiveOperations) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
populate(LiveOperations) - Method in interface com.hazelcast.spi.impl.operationservice.LiveOperationsTracker
Populate the LiveOperations
populateEmptyResult(Query, Collection<Integer>) - Method in class com.hazelcast.map.impl.query.QueryRunner
 
populateNonEmptyResult(Query, Collection<QueryableEntry>, PartitionIdSet) - Method in class com.hazelcast.map.impl.query.QueryRunner
 
populateResult(Query, long, Collection<QueryableEntry>, PartitionIdSet) - Method in class com.hazelcast.map.impl.query.AggregationResultProcessor
 
populateResult(Query, long) - Method in class com.hazelcast.map.impl.query.AggregationResultProcessor
 
populateResult(Query, long, Collection<QueryableEntry>, PartitionIdSet) - Method in class com.hazelcast.map.impl.query.QueryResultProcessor
 
populateResult(Query, long) - Method in class com.hazelcast.map.impl.query.QueryResultProcessor
 
populateResult(Query, long) - Method in interface com.hazelcast.map.impl.query.ResultProcessor
Populate an empty result for the given query type.
populateResult(Query, long, Collection<QueryableEntry>, PartitionIdSet) - Method in interface com.hazelcast.map.impl.query.ResultProcessor
Populate an non-empty result for the given query type.
populateScheduledForHolder(List<ScheduledTaskHandler>, DistributedScheduledExecutorService, int) - Method in class com.hazelcast.scheduledexecutor.impl.operations.AbstractGetAllScheduledOperation
 
PORT - Static variable in class com.hazelcast.spi.discovery.multicast.MulticastProperties
Property used to define multicast port.
PORT_AUTO_INCREMENT - Static variable in class com.hazelcast.config.ServerSocketEndpointConfig
Default port auto-increment count.
Portable - Interface in com.hazelcast.nio.serialization
Portable provides an alternative serialization method.
PORTABLE_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
PortableCachePartitionLostEvent - Class in com.hazelcast.spi.impl
 
PortableCachePartitionLostEvent() - Constructor for class com.hazelcast.spi.impl.PortableCachePartitionLostEvent
 
PortableCachePartitionLostEvent(int, UUID) - Constructor for class com.hazelcast.spi.impl.PortableCachePartitionLostEvent
 
PortableCollection - Class in com.hazelcast.spi.impl
 
PortableCollection() - Constructor for class com.hazelcast.spi.impl.PortableCollection
 
PortableCollection(Collection<Data>) - Constructor for class com.hazelcast.spi.impl.PortableCollection
 
PortableContext - Interface in com.hazelcast.internal.serialization
 
PortableDistributedObjectEvent - Class in com.hazelcast.spi.impl
 
PortableDistributedObjectEvent() - Constructor for class com.hazelcast.spi.impl.PortableDistributedObjectEvent
 
PortableDistributedObjectEvent(DistributedObjectEvent.EventType, String, String) - Constructor for class com.hazelcast.spi.impl.PortableDistributedObjectEvent
 
PortableEntryEvent - Class in com.hazelcast.spi.impl
 
PortableEntryEvent() - Constructor for class com.hazelcast.spi.impl.PortableEntryEvent
 
PortableEntryEvent(Data, Data, Data, Data, EntryEventType, UUID) - Constructor for class com.hazelcast.spi.impl.PortableEntryEvent
 
PortableEntryEvent(EntryEventType, UUID, int) - Constructor for class com.hazelcast.spi.impl.PortableEntryEvent
 
portableFactories - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
PortableFactory - Interface in com.hazelcast.nio.serialization
PortableFactory is used to create Portable instances during de-serialization.
PortableHook - Interface in com.hazelcast.internal.serialization
 
PortableItemEvent - Class in com.hazelcast.spi.impl
 
PortableItemEvent() - Constructor for class com.hazelcast.spi.impl.PortableItemEvent
 
PortableItemEvent(Data, ItemEventType, UUID) - Constructor for class com.hazelcast.spi.impl.PortableItemEvent
 
PortableMapPartitionLostEvent - Class in com.hazelcast.spi.impl
 
PortableMapPartitionLostEvent() - Constructor for class com.hazelcast.spi.impl.PortableMapPartitionLostEvent
 
PortableMapPartitionLostEvent(int, UUID) - Constructor for class com.hazelcast.spi.impl.PortableMapPartitionLostEvent
 
PortablePartitionLostEvent - Class in com.hazelcast.spi.impl
 
PortablePartitionLostEvent() - Constructor for class com.hazelcast.spi.impl.PortablePartitionLostEvent
 
PortablePartitionLostEvent(int, int, Address) - Constructor for class com.hazelcast.spi.impl.PortablePartitionLostEvent
 
PortableReader - Interface in com.hazelcast.nio.serialization
Provides a mean of reading portable fields from a binary in form of java primitives arrays of java primitives, nested portable fields and array of portable fields.
PortableReadResultSet<E> - Class in com.hazelcast.ringbuffer.impl.client
 
PortableReadResultSet() - Constructor for class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
 
PortableReadResultSet(int, List<Data>, long[], long) - Constructor for class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
 
portableSerializerAdapter - Variable in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
portableVersion - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
PortableWriter - Interface in com.hazelcast.nio.serialization
Provides a mean of writing portable fields to a binary in form of java primitives arrays of java primitives, nested portable fields and array of portable fields.
position() - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
position(int) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
position() - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
position(int) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
position(int) - Method in class com.hazelcast.internal.serialization.impl.DataInputNavigableJsonAdapter
 
position() - Method in class com.hazelcast.internal.serialization.impl.DataInputNavigableJsonAdapter
 
position(int) - Method in class com.hazelcast.internal.serialization.impl.NavigableJsonInputAdapter
Sets the position of underlying data input.
position() - Method in class com.hazelcast.internal.serialization.impl.NavigableJsonInputAdapter
Gives the current position of the cursor.
position(int) - Method in class com.hazelcast.internal.serialization.impl.StringNavigableJsonAdapter
 
position() - Method in class com.hazelcast.internal.serialization.impl.StringNavigableJsonAdapter
 
POSITIVE_INFINITY - Static variable in class com.hazelcast.query.impl.CompositeValue
Represents a value that is equal to itself and greater than any other value.
POSITIVE_INFINITY - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
POST_JOIN - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
POST_JOIN_MAP_OPERATION - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
POST_JOIN_PROXY - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
postClose() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
postClose() - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
 
postClose() - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
 
postDeregister() - Method in class com.hazelcast.internal.jmx.HazelcastMBean
 
postDestroy() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
postDestroy() - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
 
postDestroy() - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
postDestroy() - Method in class com.hazelcast.client.cp.internal.datastructures.lock.FencedLockProxy
 
postDestroy() - Method in class com.hazelcast.client.impl.proxy.ClientReliableTopicProxy
 
postDestroy() - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
postDestroy() - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
postDestroy() - Method in class com.hazelcast.client.impl.spi.ClientProxy
Called after proxy is destroyed.
postDestroy() - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
postDestroy() - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
postDestroy() - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicProxy
 
postInit(NodeEngine, Properties) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
PostJoinAwareService - Interface in com.hazelcast.internal.services
Marker interface for services that want to return operations to be executed on the cluster members after a join has been finalized.
postJoinAwareService - Variable in class com.hazelcast.map.impl.MapService
 
PostJoinMapOperation - Class in com.hazelcast.map.impl.operation
 
PostJoinMapOperation() - Constructor for class com.hazelcast.map.impl.operation.PostJoinMapOperation
 
PostJoinMapOperation.InterceptorInfo - Class in com.hazelcast.map.impl.operation
 
PostJoinProxyOperation - Class in com.hazelcast.spi.impl.proxyservice.impl.operations
 
PostJoinProxyOperation() - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.operations.PostJoinProxyOperation
 
PostJoinProxyOperation(Collection<ProxyInfo>) - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.operations.PostJoinProxyOperation
 
PostponedResponse - Class in com.hazelcast.cp.internal.raft.impl.util
The special response class that is used when a Raft entry does not return a response at the time of its commit, and will return a response with another commit in future.
PostProcessingMapStore - Interface in com.hazelcast.map
Implement this interface if you modify the value in MapStore.store(K key, V value) method.
postPublishEvent(Collection<EntryEventData>, Collection<EntryEventData>) - Method in class com.hazelcast.map.impl.event.MapEventPublisherImpl
postRegister(Boolean) - Method in class com.hazelcast.internal.jmx.HazelcastMBean
 
Pre38CacheAddInvalidationListenerTask - Class in com.hazelcast.client.impl.protocol.task.cache
 
Pre38CacheAddInvalidationListenerTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.Pre38CacheAddInvalidationListenerTask
 
Pre38MapAddNearCacheEntryListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
Client WITHOUT eventual consistent Near Cache will call this task.
Pre38MapAddNearCacheEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.Pre38MapAddNearCacheEntryListenerMessageTask
 
PRE_JOIN_CACHE_CONFIG - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
PRE_VOTE_REQUEST - Static variable in class com.hazelcast.cp.internal.raft.impl.RaftDataSerializerHook
 
PRE_VOTE_REQUEST_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
PRE_VOTE_RESPONSE - Static variable in class com.hazelcast.cp.internal.raft.impl.RaftDataSerializerHook
 
PRE_VOTE_RESPONSE_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
preCandidateState() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns pre-candidate state
Preconditions - Class in com.hazelcast.internal.util
A utility class for validating arguments and state.
PredefinedDiscoveryService - Class in com.hazelcast.spi.discovery.impl
Discovery service with a predefined and supplied discovery strategy.
PredefinedDiscoveryService(DiscoveryStrategy) - Constructor for class com.hazelcast.spi.discovery.impl.PredefinedDiscoveryService
 
preDeregister() - Method in class com.hazelcast.internal.jmx.HazelcastMBean
 
preDestroy() - Method in class com.hazelcast.client.impl.spi.ClientProxy
Called before proxy is destroyed and determines whether destroy should be done.
preDestroy() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
preDestroy() - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
predicate - Variable in class com.hazelcast.cache.impl.journal.CacheEventJournalReadOperation
 
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalReadCodec.RequestParameters
the predicate to apply before processing events
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateCodec.RequestParameters
The predicate to filter events which will be applied to the QueryCache.
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateWithValueCodec.RequestParameters
The predicate to filter events which will be applied to the QueryCache.
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyWithPredicateCodec.RequestParameters
predicate for filtering entries.
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerWithPredicateCodec.RequestParameters
predicate for filtering entries.
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.MapAggregateWithPredicateCodec.RequestParameters
predicate to filter the entries with
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPagingPredicateCodec.RequestParameters
specified query criteria.
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPredicateCodec.RequestParameters
specified query criteria.
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.MapEventJournalReadCodec.RequestParameters
the predicate to apply before processing events
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteWithPredicateCodec.RequestParameters
specified query criteria.
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchWithQueryCodec.RequestParameters
predicate to filter the entries with
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPagingPredicateCodec.RequestParameters
specified query criteria.
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPredicateCodec.RequestParameters
specified query criteria.
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.MapProjectWithPredicateCodec.RequestParameters
predicate to filter the entries with
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveAllCodec.RequestParameters
used to select entries to be removed from map.
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.MapValuesWithPagingPredicateCodec.RequestParameters
specified query criteria.
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.MapValuesWithPredicateCodec.RequestParameters
specified query criteria.
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyWithPredicateCodec.RequestParameters
The predicate for filtering entries
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerWithPredicateCodec.RequestParameters
The predicate for filtering entries
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetWithPredicateCodec.RequestParameters
Specified query criteria.
predicate - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesWithPredicateCodec.RequestParameters
Specified query criteria.
predicate - Variable in class com.hazelcast.map.impl.journal.MapEventJournalReadOperation
 
predicate(Predicate) - Method in class com.hazelcast.map.impl.query.Query.QueryBuilder
 
predicate - Variable in class com.hazelcast.query.impl.predicates.NotPredicate
 
Predicate<K,V> - Interface in com.hazelcast.query
Represents a map entry predicate.
PREDICATE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
PREDICATE_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
PREDICATE_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
PredicateBuilder - Interface in com.hazelcast.query
This interface provides functionality to build a predicate.
PredicateBuilder.EntryObject - Interface in com.hazelcast.query
This interface provides entry-level functionality related to building a predicate.
PredicateBuilderImpl - Class in com.hazelcast.query.impl
 
PredicateBuilderImpl() - Constructor for class com.hazelcast.query.impl.PredicateBuilderImpl
 
PredicateConfig - Class in com.hazelcast.config
Contains the configuration for an Predicate.
PredicateConfig() - Constructor for class com.hazelcast.config.PredicateConfig
Creates a PredicateConfig without className/implementation.
PredicateConfig(String) - Constructor for class com.hazelcast.config.PredicateConfig
Creates a PredicateConfig with the given className.
PredicateConfig(PredicateConfig) - Constructor for class com.hazelcast.config.PredicateConfig
 
PredicateConfig(Predicate) - Constructor for class com.hazelcast.config.PredicateConfig
Creates a PredicateConfig with the given implementation.
PredicateConfigHolder - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
PredicateConfigHolder(String, String, Data) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.PredicateConfigHolder
 
PredicateConfigHolderCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
PredicateConfigReadOnly - Class in com.hazelcast.internal.config
Contains the configuration for a Predicate.
PredicateConfigReadOnly(PredicateConfig) - Constructor for class com.hazelcast.internal.config.PredicateConfigReadOnly
 
PredicateDataSerializerHook - Class in com.hazelcast.query.impl.predicates
 
PredicateDataSerializerHook() - Constructor for class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
PredicateEx<T> - Interface in com.hazelcast.internal.util.function
Serializable variant of java.util.function.Predicate which declares checked exception.
predicates - Variable in class com.hazelcast.query.impl.predicates.AndPredicate
 
predicates - Variable in class com.hazelcast.query.impl.predicates.OrPredicate
 
Predicates - Class in com.hazelcast.query
A utility class to create new PredicateBuilder and Predicate instances.
PredicateUtils - Class in com.hazelcast.query.impl.predicates
 
PREFER_IPv4_STACK - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
prefetchCount - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddFlakeIdGeneratorConfigCodec.RequestParameters
how many IDs are pre-fetched on the background when one call to newId() is made
prefetchValidity - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddFlakeIdGeneratorConfigCodec.RequestParameters
for how long the pre-fetched IDs can be used
prefetchValues - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
prefetchValues - Variable in class com.hazelcast.map.impl.iterator.AbstractMapPartitionIterator
 
PrefixedDistributedObject - Interface in com.hazelcast.core
Contact point for special DistributedObject's which has prefixed name.
PreJoinAwareService - Interface in com.hazelcast.internal.services
Services which need to perform operations on a joining member just before the member is set as joined must implement this interface.
PreJoinCacheConfig<K,V> - Class in com.hazelcast.cache.impl
This subclass of CacheConfig is used to communicate cache configurations in pre-join cache operations when cluster version is at least 3.9.
PreJoinCacheConfig() - Constructor for class com.hazelcast.cache.impl.PreJoinCacheConfig
 
PreJoinCacheConfig(CacheConfig) - Constructor for class com.hazelcast.cache.impl.PreJoinCacheConfig
Constructor that copies given cacheConfig's properties to a new PreJoinCacheConfig.
PreJoinCacheConfig(CacheConfig, boolean) - Constructor for class com.hazelcast.cache.impl.PreJoinCacheConfig
 
preload(DataStructureAdapter<Object, ?>) - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
preload(DataStructureAdapter<Object, ?>) - Method in interface com.hazelcast.internal.nearcache.NearCache
Executes the Near Cache pre-loader on the given DataStructureAdapter.
prepare(CachePartitionSegment, Collection<ServiceNamespace>, int) - Method in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
 
prepare(Xid) - Method in class com.hazelcast.client.impl.proxy.txn.xa.XAResourceProxy
 
prepare() - Method in class com.hazelcast.transaction.impl.SuspendedTransaction
 
prepare() - Method in interface com.hazelcast.transaction.impl.Transaction
 
prepare() - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
prepare(NodeEngine) - Method in class com.hazelcast.transaction.impl.TransactionLog
 
prepare(Xid) - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
 
prepare() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
 
prepareEventContainerReplicationData(PartitionReplicationEvent, Collection<ServiceNamespace>) - Method in class com.hazelcast.wan.impl.DelegatingWanReplicationScheme
Collect all replication data matching the replication event and collection of namespaces being replicated.
prepareEventContainerReplicationData(PartitionReplicationEvent, Collection<ServiceNamespace>) - Method in interface com.hazelcast.wan.WanReplicationPublisher
Returns a container containing the WAN events for the given replication event and namespaces to be replicated.
prepareForNextCleanup() - Method in class com.hazelcast.cache.impl.operation.CacheClearExpiredOperation
 
prepareForNextCleanup() - Method in class com.hazelcast.map.impl.operation.MapClearExpiredOperation
 
prepareMergeRunnable() - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
prepareMergeRunnable() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorService
 
prepareMergeRunnable() - Method in class com.hazelcast.collection.impl.collection.CollectionService
 
prepareMergeRunnable() - Method in class com.hazelcast.collection.impl.queue.QueueService
 
prepareMergeRunnable() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
prepareMergeRunnable() - Method in interface com.hazelcast.internal.services.SplitBrainHandlerService
When the two separate clusters merge (resolve a split-brain), this method is called to return a Runnable, that will merge the clusters.
prepareMergeRunnable() - Method in class com.hazelcast.map.impl.MapService
 
prepareMergeRunnable() - Method in class com.hazelcast.multimap.impl.MultiMapService
 
prepareMergeRunnable() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
prepareMergeRunnable() - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
prepareMergeRunnable() - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
prepareMergeRunnable() - Method in class com.hazelcast.spi.impl.merge.AbstractSplitBrainHandlerService
 
prepareMigrationOperation(int) - Method in interface com.hazelcast.internal.crdt.CRDTReplicationAwareService
Returns a migration operation for all of the CRDT states not owned by this member.
prepareMigrationOperation(int) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterService
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.AbstractAddressMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.AbstractInvocationMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.AbstractPartitionMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheContainsKeyMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEntryProcessorMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalReadTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEventJournalSubscribeTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheFetchNearCacheInvalidationMetadataTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndRemoveMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndReplaceMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetConfigMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateEntriesMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutAllMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutIfAbsentMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheReplaceMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSetExpiryPolicyMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorAddMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.cardinality.CardinalityEstimatorEstimateMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterAddMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.crdt.pncounter.PNCounterGetMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorDisposeResultMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveAndDisposeResultMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorRetrieveResultMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorSubmitToPartitionMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnAddressMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnPartitionMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllWithIndexMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddWithIndexMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListClearMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRemoveAllMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRetainAllMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsAllMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetAllMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIndexOfMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIsEmptyMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIteratorMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListLastIndexOfMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListListIteratorMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveWithIndexMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSetMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSizeMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSubMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsKeyMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapDeleteMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEventJournalReadTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEventJournalSubscribeTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeyMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchEntriesMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchKeysMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchNearCacheInvalidationMetadataTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFetchWithQueryMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetEntryViewMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentWithMaxIdleMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutTransientMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutTransientWithMaxIdleMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutWithMaxIdleMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveIfSameMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceIfSameMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetReadCursorMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetTtlMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetWithMaxIdleMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSubmitToKeyMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryLockMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryPutMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryRemoveMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.map.MapUnlockMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.metrics.ReadMetricsMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsEntryMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsKeyMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapDeleteMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapGetMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapPutMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValueCountMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddAllMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueClearMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRemoveAllMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRetainAllMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsAllMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMaxSizeMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIsEmptyMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIteratorMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueOfferMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePeekMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePollMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePutMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemainingCapacityMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueSizeMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueTakeMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddAllMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferCapacityMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferHeadSequenceMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadManyMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadOneMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferRemainingCapacityMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferSizeMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferTailSequenceMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorShutdownMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToAddressMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToPartitionMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromAddressMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromPartitionMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromAddressMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromPartitionMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromAddressMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromPartitionMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromAddressMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromPartitionMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromAddressMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromPartitionMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromAddressMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromPartitionMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromAddressMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromPartitionMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddAllMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.set.SetClearMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRemoveAllMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRetainAllMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsAllMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.set.SetGetAllMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.set.SetIsEmptyMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.set.SetSizeMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicPublishMessageTask
 
prepareOperation() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAFinalizeTransactionMessageTask
 
prepareOperation() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterAddAndGetMessageTask
 
prepareOperation() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterDecrementAndGetMessageTask
 
prepareOperation() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndAddMessageTask
 
prepareOperation() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndIncrementMessageTask
 
prepareOperation() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetAndSetMessageTask
 
prepareOperation() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterGetMessageTask
 
prepareOperation() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterIncrementAndGetMessageTask
 
prepareOperation() - Method in class com.hazelcast.internal.longregister.client.task.LongRegisterSetMessageTask
 
prepareOperation(Operation) - Method in class com.hazelcast.internal.partition.operation.MigrationOperation
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.cache.impl.CacheService
 
prepareReplicationOperation(PartitionReplicationEvent, Collection<ServiceNamespace>) - Method in class com.hazelcast.cache.impl.CacheService
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorService
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.collection.impl.list.ListService
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.collection.impl.set.SetService
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.cp.internal.datastructures.spi.AbstractCPMigrationAwareService
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.cp.internal.RaftService
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
 
prepareReplicationOperation(int) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorPartitionContainer
 
prepareReplicationOperation(Map<String, VectorClock>, int) - Method in interface com.hazelcast.internal.crdt.CRDTReplicationAwareService
Returns a replication operation for the provided vector clocks.
prepareReplicationOperation(Map<String, VectorClock>, int) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterService
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
prepareReplicationOperation(PartitionReplicationEvent, Collection<ServiceNamespace>) - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.internal.longregister.LongRegisterService
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.map.impl.MapService
 
prepareReplicationOperation(PartitionReplicationEvent, Collection<ServiceNamespace>) - Method in class com.hazelcast.map.impl.MapService
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
prepareReplicationOperation(PartitionReplicationEvent, Collection<ServiceNamespace>) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
prepareReplicationOperation(PartitionReplicationEvent, Collection<ServiceNamespace>) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
prepareReplicationOperation(int, boolean) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorPartition
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.spi.impl.CountingMigrationAwareService
 
prepareReplicationOperation(PartitionReplicationEvent, Collection<ServiceNamespace>) - Method in class com.hazelcast.spi.impl.CountingMigrationAwareService
 
prepareReplicationOperation(PartitionReplicationEvent, Collection<ServiceNamespace>) - Method in interface com.hazelcast.spi.partition.FragmentedMigrationAwareService
Returns an operation to replicate service data and/or state for a specific partition replica and namespaces on another cluster member.
prepareReplicationOperation(PartitionReplicationEvent) - Method in interface com.hazelcast.spi.partition.MigrationAwareService
Returns an operation to replicate service data and/or state for a specific partition replica on another cluster member.
prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.transaction.impl.xa.XAService
 
prepareResult(Collection<Map.Entry<Data, Data>>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
prepareResult(Collection<Map.Entry<Data, Data>>) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
prepareToSafeShutdown() - Method in interface com.hazelcast.internal.crdt.CRDTReplicationAwareService
Prepares the service for replication and shutdown.
prepareToSafeShutdown() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterService
 
prepopulate(K, V) - Method in interface com.hazelcast.map.impl.querycache.subscriber.InternalQueryCache
Used during initial population of query cache.
prepopulate(Object, Object) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
preRegister(MBeanServer, ObjectName) - Method in class com.hazelcast.internal.jmx.HazelcastMBean
 
PRETTY_PRINT - Static variable in class com.hazelcast.internal.json.PrettyPrint
Write JSON in pretty-print, with each value on a separate line and an indentation of two spaces.
PrettyPrint - Class in com.hazelcast.internal.json
Enables human readable JSON output by inserting whitespace between values.after commas and colons.
PrettyPrint(char[]) - Constructor for class com.hazelcast.internal.json.PrettyPrint
 
PREVIOUS_CLUSTER_VERSION - Static variable in class com.hazelcast.internal.cluster.Versions
 
previousPage() - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
 
previousPage() - Method in interface com.hazelcast.query.PagingPredicate
Sets the page value to previous page.
prevLogIndex() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendRequest
 
prevLogTerm() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendRequest
 
PreVoteRequest - Class in com.hazelcast.cp.internal.raft.impl.dto
Struct for PreVoteRequest RPC.
PreVoteRequest() - Constructor for class com.hazelcast.cp.internal.raft.impl.dto.PreVoteRequest
 
PreVoteRequest(RaftEndpoint, int, int, long) - Constructor for class com.hazelcast.cp.internal.raft.impl.dto.PreVoteRequest
 
PreVoteRequestHandlerTask - Class in com.hazelcast.cp.internal.raft.impl.handler
Handles PreVoteRequest and responds to the sender with a PreVoteResponse.
PreVoteRequestHandlerTask(RaftNodeImpl, PreVoteRequest) - Constructor for class com.hazelcast.cp.internal.raft.impl.handler.PreVoteRequestHandlerTask
 
PreVoteRequestOp - Class in com.hazelcast.cp.internal.operation.integration
Carries a PreVoteRequest RPC from a Raft candidate to a follower
PreVoteRequestOp() - Constructor for class com.hazelcast.cp.internal.operation.integration.PreVoteRequestOp
 
PreVoteRequestOp(CPGroupId, PreVoteRequest) - Constructor for class com.hazelcast.cp.internal.operation.integration.PreVoteRequestOp
 
PreVoteResponse - Class in com.hazelcast.cp.internal.raft.impl.dto
Struct for response to PreVoteRequest RPC.
PreVoteResponse() - Constructor for class com.hazelcast.cp.internal.raft.impl.dto.PreVoteResponse
 
PreVoteResponse(RaftEndpoint, int, boolean) - Constructor for class com.hazelcast.cp.internal.raft.impl.dto.PreVoteResponse
 
PreVoteResponseHandlerTask - Class in com.hazelcast.cp.internal.raft.impl.handler
PreVoteResponseHandlerTask(RaftNodeImpl, PreVoteResponse) - Constructor for class com.hazelcast.cp.internal.raft.impl.handler.PreVoteResponseHandlerTask
 
PreVoteResponseOp - Class in com.hazelcast.cp.internal.operation.integration
Carries a PreVoteResponse from a Raft follower to a candidate
PreVoteResponseOp() - Constructor for class com.hazelcast.cp.internal.operation.integration.PreVoteResponseOp
 
PreVoteResponseOp(CPGroupId, PreVoteResponse) - Constructor for class com.hazelcast.cp.internal.operation.integration.PreVoteResponseOp
 
PreVoteTask - Class in com.hazelcast.cp.internal.raft.impl.task
PreVoteTask is scheduled when current leader is null, unreachable or unknown.
PreVoteTask(RaftNodeImpl, int) - Constructor for class com.hazelcast.cp.internal.raft.impl.task.PreVoteTask
 
PreVoteTimeoutTask - Class in com.hazelcast.cp.internal.raft.impl.task
PreVoteTimeoutTask is scheduled by PreVoteTask to trigger pre-voting again if this node is still a follower and a leader is not available after leader election timeout.
primary - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
primary() - Method in class com.hazelcast.client.impl.connection.Addresses
 
PRIMITIVE_TYPE_BOOLEAN - Static variable in class com.hazelcast.internal.nio.IOUtil
 
PRIMITIVE_TYPE_BYTE - Static variable in class com.hazelcast.internal.nio.IOUtil
 
PRIMITIVE_TYPE_DOUBLE - Static variable in class com.hazelcast.internal.nio.IOUtil
 
PRIMITIVE_TYPE_FLOAT - Static variable in class com.hazelcast.internal.nio.IOUtil
 
PRIMITIVE_TYPE_INTEGER - Static variable in class com.hazelcast.internal.nio.IOUtil
 
PRIMITIVE_TYPE_LONG - Static variable in class com.hazelcast.internal.nio.IOUtil
 
PRIMITIVE_TYPE_SHORT - Static variable in class com.hazelcast.internal.nio.IOUtil
 
PRIMITIVE_TYPE_UTF - Static variable in class com.hazelcast.internal.nio.IOUtil
 
print(Object) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
print(Object) - Method in class com.hazelcast.console.ConsoleApp
 
println(Object) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
println(Object) - Method in class com.hazelcast.console.ConsoleApp
 
printMemberState() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
printNodeInfo() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
printNodeInfo() - Method in interface com.hazelcast.instance.impl.NodeExtension
Called to print node information during startup
printScriptEngines() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
 
PRIORITY_GENERIC_OPERATION_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
The number of priority generic operation handler threads per member.
PriorityBlockingQueueStreamSerializer<E> - Class in com.hazelcast.internal.serialization.impl
The PriorityBlockingQueue serializer
PriorityBlockingQueueStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.PriorityBlockingQueueStreamSerializer
 
priorityBytesPending() - Method in class com.hazelcast.internal.networking.nio.NioOutboundPipeline
 
priorityFramesRead() - Method in class com.hazelcast.internal.networking.nio.NioInboundPipeline
 
priorityFramesTransceived() - Method in class com.hazelcast.internal.networking.nio.NioThread
 
priorityPacketsRead - Variable in class com.hazelcast.internal.networking.nio.InboundHandlerWithCounters
 
prioritySize() - Method in interface com.hazelcast.spi.impl.operationexecutor.impl.OperationQueue
returns the number of priority operations pending.
prioritySize() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationQueueImpl
 
priorityWriteQueue - Variable in class com.hazelcast.internal.networking.nio.NioOutboundPipeline
 
PrivateApi - Annotation Type in com.hazelcast.spi.annotation
Marker for private functionality.
ProbabilisticSplitBrainProtectionConfigBuilder - Class in com.hazelcast.config
Builder for a SplitBrainProtectionConfig configured with ProbabilisticSplitBrainProtectionFunction that considers members present in the context of a split brain protection using a probabilistic, adaptive split brain protection function.
ProbabilisticSplitBrainProtectionFunction - Class in com.hazelcast.splitbrainprotection.impl
 
ProbabilisticSplitBrainProtectionFunction(int, long, long, int, long, double) - Constructor for class com.hazelcast.splitbrainprotection.impl.ProbabilisticSplitBrainProtectionFunction
 
Probe - Annotation Type in com.hazelcast.internal.metrics
Annotation that can be placed on a field or a method of an object to indicate that it should be tracked by the MetricsRegistry when the MetricsRegistry.registerStaticMetrics(Object, String) is called.
ProbeAware - Interface in com.hazelcast.internal.metrics
Interface that can return a Probe instance.
ProbeFunction - Interface in com.hazelcast.internal.metrics
A marker interface.
ProbeLevel - Enum in com.hazelcast.internal.metrics
With the probe level one can control which probes are being tracked by the MetricsRegistry and which ones are not.
ProbeUnit - Enum in com.hazelcast.internal.metrics
Measurement unit of a Probe.
process(EntryTaskScheduler<String, Void>, Collection<ScheduledEntry<String, Void>>) - Method in class com.hazelcast.collection.impl.queue.QueueEvictionProcessor
 
process(Node) - Method in class com.hazelcast.config.AbstractXmlConfigBuilder
 
process(EntryTaskScheduler<Data, Integer>, Collection<ScheduledEntry<Data, Integer>>) - Method in class com.hazelcast.internal.locksupport.LockEvictionProcessor
 
process(MutableEntry, Object...) - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.GetCacheEntryViewEntryProcessor
 
process() - Method in class com.hazelcast.internal.networking.nio.NioOutboundPipeline
 
process(byte[]) - Method in interface com.hazelcast.internal.util.ByteArrayProcessor
 
process(byte[], int, int) - Method in interface com.hazelcast.internal.util.ByteArrayProcessor
 
process(byte[], int, int, byte[]) - Method in interface com.hazelcast.internal.util.ByteArrayProcessor
 
process(EntryTaskScheduler<K, V>, Collection<ScheduledEntry<K, V>>) - Method in interface com.hazelcast.internal.util.scheduler.ScheduledEntryProcessor
Processes all entries.
process(Map.Entry<K, V>) - Method in interface com.hazelcast.map.EntryProcessor
Process the entry without worrying about concurrency.
process(Map.Entry) - Method in class com.hazelcast.map.impl.EntryRemovingProcessor
 
process(List<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
Process store operations and returns failed operation per partition map.
process(T) - Method in interface com.hazelcast.map.impl.querycache.accumulator.AccumulatorProcessor
Processes event.
process(Sequenced) - Method in class com.hazelcast.map.impl.querycache.publisher.EventPublisherAccumulatorProcessor
 
process(EntryTaskScheduler<Object, Object>, Collection<ScheduledEntry<Object, Object>>) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapEvictionProcessor
 
processCount - Variable in class com.hazelcast.internal.networking.nio.NioPipeline
 
processedCount() - Method in class com.hazelcast.internal.util.executor.StripedExecutor
Returns the total number of processed events.
processEntryEventFilter(EventFilter, Data) - Method in class com.hazelcast.map.impl.event.AbstractFilteringStrategy
Evaluates filters of EntryEventFilter type.
processEventContainerReplicationData(int, T) - Method in interface com.hazelcast.wan.WanReplicationPublisher
Processes the WAN event container received through intra-cluster replication or migration.
processExpiredEntry(Data, R, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
processExpiredEntry(Data, R, long, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
processExpiredEntry(Data, R, long, UUID, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
processExpiredEntry(Data, R, long, long, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
processExpiredEntry(Data, R, long, long, UUID, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
processMessage() - Method in class com.hazelcast.client.impl.protocol.task.AbstractAddressMessageTask
 
processMessage() - Method in class com.hazelcast.client.impl.protocol.task.AbstractAllPartitionsMessageTask
 
processMessage() - Method in class com.hazelcast.client.impl.protocol.task.AbstractCallableMessageTask
 
processMessage() - Method in class com.hazelcast.client.impl.protocol.task.AbstractInvocationMessageTask
 
processMessage() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
processMessage() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMultiPartitionMessageTask
 
processMessage() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMultiTargetMessageTask
 
processMessage() - Method in class com.hazelcast.client.impl.protocol.task.AbstractPartitionMessageTask
 
processMessage() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
 
processMessage() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheCreateConfigMessageTask
 
processMessage() - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.AbstractAddConfigMessageTask
 
processMessage() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveAllMessageTask
 
processMessage() - Method in class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
 
processMessage() - Method in class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorGetAllScheduledMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.AddAndGetMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.AlterMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.ApplyMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.CompareAndSetMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetAndAddMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetAndSetMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.client.GetMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.ApplyMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.CompareAndSetMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.ContainsMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.GetMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.client.SetMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.AwaitMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.CountDownMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.GetCountMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.GetRoundMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.client.TrySetCountMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.GetLockOwnershipStateMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.LockMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.TryLockMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.lock.client.UnlockMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.AcquirePermitsMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.AvailablePermitsMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.ChangePermitsMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.DrainPermitsMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.GetSemaphoreTypeMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.InitSemaphoreMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.client.ReleasePermitsMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.spi.client.CreateRaftGroupMessageTask
 
processMessage() - Method in class com.hazelcast.cp.internal.datastructures.spi.client.DestroyRaftObjectMessageTask
 
processMessage() - Method in class com.hazelcast.flakeidgen.impl.client.NewIdBatchMessageTask
 
processPartitionRuntimeState(PartitionRuntimeState) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
Sets the partitionState if the node is started and the state is sent by the master known by this node.
processRequest(TextCommand) - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
processRequest(TextCommand) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
processResource(String, InputStream, List<Relocator>) - Method in class com.hazelcast.buildutils.HazelcastManifestTransformer
 
project(Projection<? super Map.Entry<K, V>, R>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
project(Projection<? super Map.Entry<K, V>, R>, Predicate<K, V>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
project(Projection<? super Map.Entry<K, V>, R>) - Method in interface com.hazelcast.map.IMap
Applies the projection logic on all map entries and returns the result
project(Projection<? super Map.Entry<K, V>, R>, Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
Applies the projection logic on map entries filtered with the Predicated and returns the result
project(Projection<? super Map.Entry<K, V>, R>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
project(Projection<? super Map.Entry<K, V>, R>, Predicate<K, V>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
projection - Variable in class com.hazelcast.cache.impl.journal.CacheEventJournalReadOperation
 
projection - Variable in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalReadCodec.RequestParameters
the projection to apply to journal events
projection - Variable in class com.hazelcast.client.impl.protocol.codec.MapEventJournalReadCodec.RequestParameters
the projection to apply to journal events
projection - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchWithQueryCodec.RequestParameters
projection to transform the entries with
projection - Variable in class com.hazelcast.client.impl.protocol.codec.MapProjectCodec.RequestParameters
projection to transform the entries with.
projection - Variable in class com.hazelcast.client.impl.protocol.codec.MapProjectWithPredicateCodec.RequestParameters
projection to transform the entries with.
projection - Variable in class com.hazelcast.map.impl.journal.MapEventJournalReadOperation
 
projection(Projection) - Method in class com.hazelcast.map.impl.query.Query.QueryBuilder
 
Projection<I,O> - Interface in com.hazelcast.projection
Enables transforming object into other objects.
PROJECTION_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
PROJECTION_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ProjectionDataSerializerHook - Class in com.hazelcast.projection.impl
 
ProjectionDataSerializerHook() - Constructor for class com.hazelcast.projection.impl.ProjectionDataSerializerHook
 
Projections - Class in com.hazelcast.projection
A utility class to create basic Projection instances.
PROMOTE_LITE_MEMBER - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
PromoteLiteMemberOp - Class in com.hazelcast.internal.cluster.impl.operations
Promotes caller lite member to a normal member.
PromoteLiteMemberOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.PromoteLiteMemberOp
 
promoteLocalLiteMember() - Method in class com.hazelcast.client.impl.proxy.ClientClusterProxy
 
promoteLocalLiteMember() - Method in interface com.hazelcast.cluster.Cluster
Promotes local lite member to data member.
promoteLocalLiteMember() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
PromoteMemberRequest - Class in com.hazelcast.internal.management.request
 
PromoteMemberRequest() - Constructor for class com.hazelcast.internal.management.request.PromoteMemberRequest
 
promoteSuspended() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
promoteToCPMember() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Promotes the local Hazelcast member to the CP role.
promoteToCPMember() - Method in class com.hazelcast.cp.internal.RaftService
 
promoteToDataMember(Address, UUID) - Method in class com.hazelcast.internal.cluster.impl.MembershipManager
 
promoteToLoadedOnMigration() - Method in class com.hazelcast.map.impl.MapKeyLoader
Advances the state of the map key loader to State#LOADED
PROMOTION_COMMIT - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
PromotionCommitOperation - Class in com.hazelcast.internal.partition.operation
Used for committing a promotion on destination.
PromotionCommitOperation() - Constructor for class com.hazelcast.internal.partition.operation.PromotionCommitOperation
 
PromotionCommitOperation(PartitionRuntimeState, Collection<MigrationInfo>, UUID) - Constructor for class com.hazelcast.internal.partition.operation.PromotionCommitOperation
 
PROP_CLEANUP_OPERATION_COUNT - Static variable in class com.hazelcast.cache.impl.eviction.CacheClearExpiredRecordsTask
 
PROP_CLEANUP_OPERATION_COUNT - Static variable in class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
 
PROP_CLEANUP_PERCENTAGE - Static variable in class com.hazelcast.cache.impl.eviction.CacheClearExpiredRecordsTask
 
PROP_CLEANUP_PERCENTAGE - Static variable in class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
 
PROP_EXPIRATION_TASK_INITIAL_DELAY_SECONDS - Static variable in interface com.hazelcast.internal.nearcache.NearCache
 
PROP_EXPIRATION_TASK_PERIOD_SECONDS - Static variable in interface com.hazelcast.internal.nearcache.NearCache
 
PROP_FORCED_EVICTION_RETRY_COUNT - Static variable in class com.hazelcast.map.impl.operation.WithForcedEviction
 
PROP_LISTENER_WITH_PREDICATE_PRODUCES_NATURAL_EVENT_TYPES - Static variable in class com.hazelcast.map.impl.event.MapEventPublisherImpl
When true, enables processing of entry events for listeners with predicates to fit with "query cache" concept: for example when the original event indicates an update from an old value that does not match the predicate to a new value that does match, then the entry listener will be notified with an ADDED event.
PROP_PRIMARY_DRIVES_BACKUP - Static variable in class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
 
PROP_TASK_PERIOD_SECONDS - Static variable in class com.hazelcast.cache.impl.eviction.CacheClearExpiredRecordsTask
 
PROP_TASK_PERIOD_SECONDS - Static variable in class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
 
properties - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
properties - Variable in class com.hazelcast.config.AbstractWanPublisherConfig
 
properties - Variable in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
 
properties() - Method in interface com.hazelcast.internal.nio.IOService
 
properties() - Method in class com.hazelcast.internal.nio.NodeIOService
 
propertiesByInstanceItself(HazelcastInstance) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
Create the Properties with the provided instance itself.
propertiesByInstanceName(String) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
Create the Properties with the provided instance name.
propertiesByLocation(String) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
Create the Properties with the provided config file location.
PropertiesUtil - Class in com.hazelcast.client.impl.protocol.util
 
PROPERTY_CIPHER_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure Cipher algorithm name.
PROPERTY_KEY_LENGTH_BITS - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure key length (in bits).
PROPERTY_PASSWORD_FILE - Static variable in class com.hazelcast.config.replacer.EncryptionReplacer
Replacer property name to configure path to a password file which content should be used as part of the encryption password.
PROPERTY_PASSWORD_NETWORK_INTERFACE - Static variable in class com.hazelcast.config.replacer.EncryptionReplacer
Replacer property name to configure network interface name used to retrieve MAC address used as part of the encryption password.
PROPERTY_PASSWORD_USER_PROPERTIES - Static variable in class com.hazelcast.config.replacer.EncryptionReplacer
Replacer property name to configure true/false flag contolling if users properties should be used as part of the encryption password.
PROPERTY_SALT_LENGTH_BYTES - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure salt length (in bytes).
PROPERTY_SECRET_KEY_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure SecretKeySpec algorithm name.
PROPERTY_SECRET_KEY_FACTORY_ALGORITHM - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure SecretKeyFactory algorithm name.
PROPERTY_SECURITY_PROVIDER - Static variable in class com.hazelcast.config.replacer.AbstractPbeReplacer
Replacer property name to configure Java Security provider name used for Cipher and SecretKeyFactory selection.
PropertyDefinition - Interface in com.hazelcast.config.properties
This interface describes an extended approach of the currently available pure property based configuration inside Hazelcast and helps implementing an automatic and transparent way to verify configuration as well as converting types based on provided validators and converters.
PropertyReplacer - Class in com.hazelcast.config.replacer
ConfigReplacer for replacing property names with property values for properties provided in PropertyReplacer.init(Properties) method.
PropertyReplacer() - Constructor for class com.hazelcast.config.replacer.PropertyReplacer
 
PropertyTypeConverter - Enum in com.hazelcast.config.properties
This enum class contains basic TypeConverter implementations to convert strings to all common basic Java types.
PROTOCOL_LENGTH - Static variable in class com.hazelcast.internal.nio.Protocols
The length in bytes of the of the protocol-string
Protocols - Class in com.hazelcast.internal.nio
First bytes to send a node that defines selected protocol
protocolType - Variable in class com.hazelcast.config.EndpointConfig
 
ProtocolType - Enum in com.hazelcast.instance
Types of server sockets.
provide(MetricConsumer) - Method in class com.hazelcast.internal.metrics.managementcenter.Metric
Consumes the Metric with the given MetricConsumer.
provide(EndpointQualifier) - Method in interface com.hazelcast.internal.networking.ChannelInitializerProvider
 
provide(EndpointQualifier) - Method in class com.hazelcast.internal.nio.tcp.DefaultChannelInitializerProvider
 
provideClientChannelInitializer(EndpointConfig) - Method in class com.hazelcast.internal.nio.tcp.DefaultChannelInitializerProvider
 
provideDynamicMetrics(MetricTaggerSupplier, MetricsExtractor) - Method in class com.hazelcast.cp.internal.RaftService
 
provideDynamicMetrics(MetricTaggerSupplier, MetricsExtractor) - Method in interface com.hazelcast.internal.metrics.DynamicMetricsProvider
Metrics collection callback that is called in every metric collection cycle.
provideDynamicMetrics(MetricTaggerSupplier, MetricsExtractor) - Method in class com.hazelcast.internal.networking.nio.NioNetworking
 
provideDynamicMetrics(MetricTaggerSupplier, MetricsExtractor) - Method in class com.hazelcast.internal.nio.tcp.TcpIpAcceptor
 
provideDynamicMetrics(MetricTaggerSupplier, MetricsExtractor) - Method in class com.hazelcast.internal.nio.tcp.TcpIpEndpointManager
 
provideMemberChannelInitializer(EndpointConfig) - Method in class com.hazelcast.internal.nio.tcp.DefaultChannelInitializerProvider
 
provideMetrics(Object...) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
 
provideMetrics(Object...) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
provideStaticMetrics(MetricsRegistry) - Method in class com.hazelcast.client.impl.spi.impl.ClientExecutionServiceImpl
 
provideStaticMetrics(MetricsRegistry) - Method in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
provideStaticMetrics(MetricsRegistry) - Method in interface com.hazelcast.internal.metrics.StaticMetricsProvider
 
provideStaticMetrics(MetricsRegistry) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
provideStaticMetrics(MetricsRegistry) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
provideStaticMetrics(MetricsRegistry) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationThread
 
provideStaticMetrics(MetricsRegistry) - Method in class com.hazelcast.spi.impl.operationparker.impl.OperationParkerImpl
 
provideStaticMetrics(MetricsRegistry) - Method in class com.hazelcast.spi.impl.operationservice.impl.InboundResponseHandlerSupplier
 
provideStaticMetrics(MetricsRegistry) - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationMonitor
 
provideStaticMetrics(MetricsRegistry) - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
 
provideStaticMetrics(MetricsRegistry) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
provideStaticMetrics(MetricsRegistry) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
 
provideTextChannelInitializer(EndpointConfig, boolean) - Method in class com.hazelcast.internal.nio.tcp.DefaultChannelInitializerProvider
 
provideUnifiedChannelInitializer() - Method in class com.hazelcast.internal.nio.tcp.DefaultChannelInitializerProvider
 
provideWanChannelInitializer(EndpointConfig) - Method in class com.hazelcast.internal.nio.tcp.DefaultChannelInitializerProvider
 
proxies - Variable in class com.hazelcast.client.impl.protocol.codec.ClientCreateProxiesCodec.RequestParameters
proxies that will be created Each entry's key is distributed object name.
proxyCount - Variable in class com.hazelcast.internal.management.dto.ProxyServiceDTO
 
ProxyFactoryConfig - Class in com.hazelcast.client.config
This class is related to SPI.
ProxyFactoryConfig() - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
 
ProxyFactoryConfig(String, String) - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
 
ProxyFactoryConfig(String, ClientProxyFactory) - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
 
ProxyFactoryConfig(ProxyFactoryConfig) - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
 
ProxyInfo - Class in com.hazelcast.spi.impl.proxyservice.impl
 
ProxyInfo(String, String) - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.ProxyInfo
 
ProxyManager - Class in com.hazelcast.client.impl.spi
The ProxyManager handles client proxy instantiation and retrieval at start and runtime by registering corresponding service manager names and their ClientProxyFactorys.
ProxyManager(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.impl.spi.ProxyManager
 
proxyName - Variable in class com.hazelcast.client.impl.protocol.codec.CPGroupCreateCPGroupCodec.RequestParameters
The proxy name of this data structure instance
proxyName - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreGetSemaphoreTypeCodec.RequestParameters
Name of the ISemaphore proxy
proxyName - Variable in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
ProxyRegistry - Class in com.hazelcast.spi.impl.proxyservice.impl
A ProxyRegistry contains all proxies for a given service.
ProxyService - Interface in com.hazelcast.spi.impl.proxyservice
A CoreService responsible for managing the DistributedObject proxies.
ProxyServiceDTO - Class in com.hazelcast.internal.management.dto
A Serializable DTO for ProxyServiceMBean.
ProxyServiceDTO() - Constructor for class com.hazelcast.internal.management.dto.ProxyServiceDTO
 
ProxyServiceDTO(ProxyService) - Constructor for class com.hazelcast.internal.management.dto.ProxyServiceDTO
 
ProxyServiceImpl - Class in com.hazelcast.spi.impl.proxyservice.impl
 
ProxyServiceImpl(NodeEngineImpl) - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
 
ProxyServiceMBean - Class in com.hazelcast.internal.jmx
Management bean for ProxyService
ProxyServiceMBean(HazelcastInstance, ProxyService, ManagementService) - Constructor for class com.hazelcast.internal.jmx.ProxyServiceMBean
 
ProxySessionManagerService - Class in com.hazelcast.cp.internal.session
Server-side implementation of Raft proxy session manager
ProxySessionManagerService(NodeEngine) - Constructor for class com.hazelcast.cp.internal.session.ProxySessionManagerService
 
publish(E) - Method in class com.hazelcast.client.impl.proxy.ClientReliableTopicProxy
 
publish(E) - Method in class com.hazelcast.client.impl.proxy.ClientTopicProxy
 
publish(String, String, Object, int, Extractors) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheEventService
 
publish(String, String, E, int, Extractors) - Method in interface com.hazelcast.map.impl.querycache.QueryCacheEventService
Publishes query-cache events locally.
publish(String, String, EventData, int, Extractors) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheEventService
 
publish(E) - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicProxy
 
PUBLISH - Static variable in class com.hazelcast.topic.impl.TopicDataSerializerHook
 
publish(E) - Method in class com.hazelcast.topic.impl.TopicProxy
 
publish(E) - Method in class com.hazelcast.topic.impl.TotalOrderedTopicProxy
 
publish(E) - Method in interface com.hazelcast.topic.ITopic
Publishes the message to all subscribers of this topic.
PUBLISH_ACTIVE_CP_MEMBERS_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
PUBLISH_COMPLETED_MIGRATIONS - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
PUBLISH_RESULT - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
PublishActiveCPMembersOp - Class in com.hazelcast.cp.internal.raftop.metadata
CP members use this operation to broadcast their current active CP member list to the AP Hazelcast members.
PublishActiveCPMembersOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.PublishActiveCPMembersOp
 
PublishActiveCPMembersOp(RaftGroupId, long, Collection<CPMemberInfo>) - Constructor for class com.hazelcast.cp.internal.raftop.metadata.PublishActiveCPMembersOp
 
publishAntiEntropyEvent(WanAntiEntropyEvent) - Method in interface com.hazelcast.wan.WanReplicationPublisher
Publishes a WAN anti-entropy event.
publishBatchedEvents(String, CacheEventType, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
publishCachePartitionLostEvent(String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
PublishCompletedMigrationsOperation - Class in com.hazelcast.internal.partition.operation
Sent by master member to other cluster members to publish completed migrations and the new partition state version.
PublishCompletedMigrationsOperation() - Constructor for class com.hazelcast.internal.partition.operation.PublishCompletedMigrationsOperation
 
PublishCompletedMigrationsOperation(Collection<MigrationInfo>) - Constructor for class com.hazelcast.internal.partition.operation.PublishCompletedMigrationsOperation
 
publishDouble(String, double, Set<MetricTarget>) - Method in class com.hazelcast.internal.metrics.jmx.JmxPublisher
 
publishDouble(String, double, Set<MetricTarget>) - Method in class com.hazelcast.internal.metrics.managementcenter.ManagementCenterPublisher
 
publishDouble(String, double, Set<MetricTarget>) - Method in interface com.hazelcast.internal.metrics.MetricsPublisher
Publish the given metric with a double value.
publishEntryEvent(String, EntryEventType, Data, Object, Object) - Method in class com.hazelcast.multimap.impl.MultiMapEventsPublisher
 
publishEntryEvent(String, EntryEventType, Data, Object, Object) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
PUBLISHER_CREATE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
PublisherAccumulatorFactory - Class in com.hazelcast.map.impl.querycache.publisher
Factory which is responsible for creating Accumulator implementations.
PublisherAccumulatorFactory(QueryCacheContext) - Constructor for class com.hazelcast.map.impl.querycache.publisher.PublisherAccumulatorFactory
 
PublisherAccumulatorHandler - Class in com.hazelcast.map.impl.querycache.publisher
Handler for processing of event data in an Accumulator.
PublisherAccumulatorHandler(QueryCacheContext, AccumulatorProcessor<Sequenced>) - Constructor for class com.hazelcast.map.impl.querycache.publisher.PublisherAccumulatorHandler
 
PublisherContext - Interface in com.hazelcast.map.impl.querycache.publisher
Context for a publisher.
PublisherCreateOperation - Class in com.hazelcast.map.impl.querycache.subscriber.operation
An idempotent create operation which creates publisher side functionality.
PublisherCreateOperation() - Constructor for class com.hazelcast.map.impl.querycache.subscriber.operation.PublisherCreateOperation
 
PublisherCreateOperation(AccumulatorInfo) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.operation.PublisherCreateOperation
 
publisherId - Variable in class com.hazelcast.config.AbstractWanPublisherConfig
 
PublisherRegistry - Class in com.hazelcast.map.impl.querycache.publisher
Registry of mappings like cacheId to PartitionAccumulatorRegistry.
PublisherRegistry(QueryCacheContext, String) - Constructor for class com.hazelcast.map.impl.querycache.publisher.PublisherRegistry
 
publishEvent(CacheEventContext) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
publishEvent(CacheEventContext) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
publishEvent(String, CacheEventSet, int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
publishEvent(CacheEventContext) - Method in interface com.hazelcast.cache.impl.ICacheService
 
publishEvent(String, CacheEventSet, int) - Method in interface com.hazelcast.cache.impl.ICacheService
 
publishEvent(ItemEventType, Data) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
 
publishEvent(ItemEventType, Data) - Method in class com.hazelcast.collection.impl.queue.operations.QueueOperation
 
publishEvent(Address, String, EntryEventType, Data, Object, Object) - Method in interface com.hazelcast.map.impl.event.MapEventPublisher
Publish an event to the event subsystem.
publishEvent(Address, String, EntryEventType, Data, Object, Object, Object) - Method in interface com.hazelcast.map.impl.event.MapEventPublisher
Publish an event to the event subsystem.
publishEvent(Address, String, EntryEventType, Data, Object, Object) - Method in class com.hazelcast.map.impl.event.MapEventPublisherImpl
 
publishEvent(Address, String, EntryEventType, Data, Object, Object, Object) - Method in class com.hazelcast.map.impl.event.MapEventPublisherImpl
 
publishEvent(EntryEventType, Data, Object, Object) - Method in class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
 
publishEvent(String, String, Object, int) - Method in interface com.hazelcast.spi.impl.eventservice.EventService
Publishes an event for all event registrations belonging to the specified service name and topic.
publishEvent(String, EventRegistration, Object, int) - Method in interface com.hazelcast.spi.impl.eventservice.EventService
Publishes an event for a specific event registration.
publishEvent(String, Collection<EventRegistration>, Object, int) - Method in interface com.hazelcast.spi.impl.eventservice.EventService
Publishes an event for multiple event registrations.
publishEvent(String, String, Object, int) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
publishEvent(String, EventRegistration, Object, int) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
publishEvent(String, Collection<EventRegistration>, Object, int) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
publishEventInternal(Collection<EventRegistration>, Object, int) - Method in class com.hazelcast.map.impl.event.MapEventPublisherImpl
 
publishEventLost(QueryCacheContext, String, String, int, Extractors) - Static method in class com.hazelcast.map.impl.querycache.subscriber.EventPublisherHelper
 
publishInternal(Object) - Method in class com.hazelcast.topic.impl.TopicProxySupport
Publishes the message and increases the local statistics for the number of published messages.
publishLoadAsWanUpdate(Data, Object) - Method in class com.hazelcast.map.impl.operation.MapOperation
 
publishLong(String, long, Set<MetricTarget>) - Method in class com.hazelcast.internal.metrics.jmx.JmxPublisher
 
publishLong(String, long, Set<MetricTarget>) - Method in class com.hazelcast.internal.metrics.managementcenter.ManagementCenterPublisher
 
publishLong(String, long, Set<MetricTarget>) - Method in interface com.hazelcast.internal.metrics.MetricsPublisher
Publish the given metric with a long value.
publishMapEvent(Address, String, EntryEventType, int) - Method in interface com.hazelcast.map.impl.event.MapEventPublisher
 
publishMapEvent(Address, String, EntryEventType, int) - Method in class com.hazelcast.map.impl.event.MapEventPublisherImpl
 
publishMapPartitionLostEvent(Address, String, int) - Method in interface com.hazelcast.map.impl.event.MapEventPublisher
 
publishMapPartitionLostEvent(Address, String, int) - Method in class com.hazelcast.map.impl.event.MapEventPublisherImpl
 
publishMessage(String, Object, boolean) - Method in class com.hazelcast.topic.impl.TopicService
 
publishMetrics() - Method in class com.hazelcast.internal.networking.nio.NioOutboundPipeline
 
publishMultiMapEvent(String, EntryEventType, int) - Method in class com.hazelcast.multimap.impl.MultiMapEventsPublisher
 
publishMultiMapEvent(String, EntryEventType, int) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
PublishOperation - Class in com.hazelcast.topic.impl
ITopic publication operation used when global ordering is enabled (all nodes listening to the same topic get their messages in the same order).
PublishOperation() - Constructor for class com.hazelcast.topic.impl.PublishOperation
 
PublishOperation(String, Data) - Constructor for class com.hazelcast.topic.impl.PublishOperation
 
publishRemoteEvent(String, Collection<EventRegistration>, Object, int) - Method in interface com.hazelcast.spi.impl.eventservice.EventService
Publishes an event for multiple event registrations, excluding local ones.
publishRemoteEvent(String, Collection<EventRegistration>, Object, int) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
Publishes an event for multiple event registrations, excluding local ones.
publishReplicationEvent(WanReplicationEvent) - Method in class com.hazelcast.wan.impl.DelegatingWanReplicationScheme
Publishes a replication event to all publishers to which this publisher delegates.
publishReplicationEvent(WanReplicationEvent) - Method in interface com.hazelcast.wan.WanReplicationPublisher
Publish the eventObject WAN replication event.
publishReplicationEventBackup(WanReplicationEvent) - Method in class com.hazelcast.wan.impl.DelegatingWanReplicationScheme
Publishes a backup replication event to all publishers to which this publisher delegates.
publishReplicationEventBackup(WanReplicationEvent) - Method in interface com.hazelcast.wan.WanReplicationPublisher
Publish the eventObject WAN replication event backup.
publishRequest(TextCommand) - Method in class com.hazelcast.internal.nio.ascii.TextDecoder
 
publishWanEvent(String, InternalWanReplicationEvent) - Method in class com.hazelcast.map.impl.event.MapEventPublisherImpl
Publishes the event to the WanReplicationPublisher configured for this map.
publishWanRemove(String, Data) - Method in interface com.hazelcast.cache.impl.event.CacheWanEventPublisher
This method will create a wrapper object using the given CacheEntryView and place it to wan replication queues.
publishWanRemove(Data) - Method in class com.hazelcast.cache.impl.operation.CacheOperation
 
publishWanRemove(String, Data) - Method in interface com.hazelcast.map.impl.event.MapEventPublisher
Notifies the WAN subsystem of a map entry removal on a replica owner.
publishWanRemove(String, Data) - Method in class com.hazelcast.map.impl.event.MapEventPublisherImpl
 
publishWanRemove(Data) - Method in class com.hazelcast.map.impl.operation.MapOperation
 
publishWanUpdate(String, CacheEntryView<Data, Data>) - Method in interface com.hazelcast.cache.impl.event.CacheWanEventPublisher
This method will create a wrapper object using the given CacheEntryView and place it to wan replication queues.
publishWanUpdate(Data, CacheRecord) - Method in class com.hazelcast.cache.impl.operation.CacheOperation
 
publishWanUpdate(Data, Data, CacheRecord) - Method in class com.hazelcast.cache.impl.operation.CacheOperation
 
publishWanUpdate(Data, Data, Data, CacheRecord) - Method in class com.hazelcast.cache.impl.operation.CacheOperation
 
publishWanUpdate(String, EntryView<Data, Data>, boolean) - Method in interface com.hazelcast.map.impl.event.MapEventPublisher
Notifies the WAN subsystem of a map update on a replica owner.
publishWanUpdate(String, EntryView<Data, Data>, boolean) - Method in class com.hazelcast.map.impl.event.MapEventPublisherImpl
 
publishWanUpdate(Data, Object) - Method in class com.hazelcast.map.impl.operation.MapOperation
 
PURGE_ALLOWED_DURING_PASSIVE_STATE_TX_BACKUP_LOG - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
PURGE_TX_BACKUP_LOG - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
PurgeAllowedDuringPassiveStateTxBackupLogOperation - Class in com.hazelcast.transaction.impl.operations
 
PurgeAllowedDuringPassiveStateTxBackupLogOperation() - Constructor for class com.hazelcast.transaction.impl.operations.PurgeAllowedDuringPassiveStateTxBackupLogOperation
 
PurgeAllowedDuringPassiveStateTxBackupLogOperation(UUID) - Constructor for class com.hazelcast.transaction.impl.operations.PurgeAllowedDuringPassiveStateTxBackupLogOperation
 
purgeBackupLog(UUID) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
purgeStaleEntries() - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
Removes any stale entries whose keys have been finalized.
PurgeTxBackupLogOperation - Class in com.hazelcast.transaction.impl.operations
 
PurgeTxBackupLogOperation() - Constructor for class com.hazelcast.transaction.impl.operations.PurgeTxBackupLogOperation
 
PurgeTxBackupLogOperation(UUID) - Constructor for class com.hazelcast.transaction.impl.operations.PurgeTxBackupLogOperation
 
put(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Associates the specified value with the specified key in the cache using a custom ExpiryPolicy.
put(Data, Object, ExpiryPolicy, UUID, boolean, boolean, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
put(Data, Object, ExpiryPolicy, UUID, boolean, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
put(Data, Object, ExpiryPolicy, UUID, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
PUT - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
put(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
 
put(K, V, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.CacheProxy
 
put(Data, Object, ExpiryPolicy, UUID, 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.
put(Data, CacheRecord) - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap
 
put(K, V) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
put(K, V, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
put(K, V) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
put(K, V, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
put(K, V) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
put(E) - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
put(K, V, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
put(K, V) - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
put(K, V) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
put(K, V, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
put(K, V) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMultiMapProxy
 
put(E) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
put(K, V) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
put(K, V) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
put(K, V) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
put(K, V) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
put(K, V) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
put(String, String, Object) - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
put(String, String, Object, int) - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
put(String, String, Object) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
put(String, String, Object, int) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
put(K, V) - Method in class com.hazelcast.internal.dynamicconfig.AggregatingMap
 
put(LockStoreImpl) - Method in class com.hazelcast.internal.locksupport.LockStoreContainer
 
put(K, Data, V, Data) - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
put(K, Data, V, Data) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
put(K, Data, V, Data) - Method in interface com.hazelcast.internal.nearcache.NearCache
Puts (associates) a value with the given key.
put(K, Data, V, Data) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
Puts (associates) a value with the given key.
put(int, int, V) - Method in class com.hazelcast.internal.util.collection.BiInt2ObjectMap
Put a value into the map.
put(K1, K2, V) - Method in class com.hazelcast.internal.util.collection.ComposedKeyMap
 
put(Integer, V) - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
 
put(int, V) - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
Overloaded version of Map.put(Object, Object) that takes a primitive int key.
put(K, V) - Method in class com.hazelcast.internal.util.collection.InternalListMultiMap
Put value to a given key.
put(K, V) - Method in class com.hazelcast.internal.util.collection.InternalSetMultimap
Associate value to a given key.
put(long, long) - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
 
put(Long, Long) - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
 
put(long, long) - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
 
put(long, long) - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
 
put(Long, V) - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
 
put(long, V) - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
Overloaded version of Map.put(Object, Object) that takes a primitive long key.
put(E) - Method in class com.hazelcast.internal.util.concurrent.MPSCQueue
 
put(K, V) - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
Maps the specified key to the specified value in this table.
put(K, V) - Method in interface com.hazelcast.map.BaseMap
Associates the specified value with the specified key in this map.
put(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.BaseMap
Associates the specified value with the specified key in this map with a given ttl (time to live) value.
put(K, V) - Method in interface com.hazelcast.map.IMap
Associates the specified value with the specified key in this map.
put(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Puts an entry into this map with a given TTL (time to live) value.
put(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Puts an entry into this map with a given TTL (time to live) value and max idle time value.
PUT - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
put(K, V) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
put(K, V, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
put(Data, Object, long, long) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
put(Data, Object, long, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
put(K, R) - Method in interface com.hazelcast.map.impl.recordstore.Storage
 
put(Data, R) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
put(Object, Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
put(Object, Object, long, TimeUnit) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
put(K, V) - Method in interface com.hazelcast.multimap.BaseMultiMap
Stores a key-value pair in the multimap.
PUT - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
put(K, V) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
put(K, V) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
 
put(K, V) - Method in interface com.hazelcast.multimap.MultiMap
Stores a key-value pair in the multimap.
put(String, Object) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
 
PUT - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
put(Object, Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
put(Object, Object, long, TimeUnit, boolean) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
put(K, ReplicatedRecord<K, V>) - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
 
put(Object, Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
put(Object, Object, long, TimeUnit, boolean) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
put(K, V) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
put(K, V, long, TimeUnit) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
put(K, V, long, TimeUnit) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Associates a given value to the specified key and replicates it to the cluster.
put(Object, Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
put(K, V) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.put(Object, Object).
put(K, V, long, TimeUnit) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.put(Object, Object, long, TimeUnit).
put(K, V) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
Stores a key-value pair in the multimap.
PUT_ALL - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
PUT_ALL - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
PUT_ALL - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
PUT_ALL_BACKUP - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
PUT_ALL_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
PUT_ALL_OP_FACTORY - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
PUT_ALL_PARTITION_AWARE_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
PUT_BACKUP - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
PUT_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
PUT_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
PUT_FROM_LOAD_ALL - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
PUT_FROM_LOAD_ALL_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
PUT_IF_ABSENT - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
PUT_IF_ABSENT - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
PUT_IF_ABSENT - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
PUT_IF_ABSENT_WITH_EXPIRY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
PUT_REMOTE_TX - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
PUT_REMOTE_TX_BACKUP - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
PUT_RESULT - Static variable in class com.hazelcast.durableexecutor.impl.DurableExecutorDataSerializerHook
 
PUT_RESULT_BACKUP - Static variable in class com.hazelcast.durableexecutor.impl.DurableExecutorDataSerializerHook
 
PUT_TIME_TAKEN_NANOS - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
PUT_TRANSIENT - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
PUT_TRANSIENT_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
PUT_TRANSIENT_WITH_EXPIRY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
PUT_WITH_EXPIRY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
putAll(Map<? extends K, ? extends V>, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Copies all of the entries from the given map to the cache using a custom ExpiryPolicy.
putAll(Map<? extends K, ? extends V>) - Method in class com.hazelcast.cache.impl.CacheProxy
 
putAll(Map<? extends K, ? extends V>, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.CacheProxy
 
putAll(Map<? extends K, ? extends V>) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
putAll(Map<? extends K, ? extends V>, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
putAll(Map<? extends K, ? extends V>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
putAll(Map<? extends K, ? extends V>) - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
putAll(Map<K, V>) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
putAll(Map<K, V>) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
putAll(Map<K, V>) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
putAll(Map<K, V>) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
putAll(Map<K, V>) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
putAll(Map<? extends K, ? extends V>) - Method in class com.hazelcast.internal.dynamicconfig.AggregatingMap
 
putAll(Map<? extends Integer, ? extends V>) - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
 
putAll(Map<? extends Long, ? extends Long>) - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
 
putAll(Long2LongMap) - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
 
putAll(Long2LongMap) - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
 
putAll(Map<? extends Long, ? extends V>) - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
 
putAll(Map<? extends K, ? extends V>) - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
Copies all of the mappings from the specified map to this one.
putAll(Map<? extends K, ? extends V>) - Method in interface com.hazelcast.map.IMap
putAll(Map<UUID, Long>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.TxnReservedCapacityCounter
Puts all supplied transactions capacity counts into this counter.
putAll(Map<UUID, Long>) - Method in class com.hazelcast.map.impl.mapstore.writebehind.TxnReservedCapacityCounterImpl
Increments 2 counters with supplied txn reserved capacity counts.
putAll(Map<? extends K, ? extends V>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
putAll(Map<? extends K, ? extends V>) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
putAllAsync(Map<? extends K, ? extends V>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
putAllAsync(Map<? extends K, ? extends V>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
This version does not support batching.
PutAllBackupOperation - Class in com.hazelcast.map.impl.operation
 
PutAllBackupOperation(String, MapEntries, List<RecordInfo>, boolean) - Constructor for class com.hazelcast.map.impl.operation.PutAllBackupOperation
 
PutAllBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.PutAllBackupOperation
 
putAllInternal(Map<? extends K, ? extends V>, ExpiryPolicy, Map<Object, Data>, List<Map.Entry<Data, Data>>[], long) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
PutAllOperation - Class in com.hazelcast.map.impl.operation
Inserts the MapEntries for a single partition to the local RecordStore.
PutAllOperation() - Constructor for class com.hazelcast.map.impl.operation.PutAllOperation
 
PutAllOperation(String, MapEntries) - Constructor for class com.hazelcast.map.impl.operation.PutAllOperation
 
PutAllOperation - Class in com.hazelcast.replicatedmap.impl.operation
Puts a set of records to the replicated map.
PutAllOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.PutAllOperation
 
PutAllOperation(String, ReplicatedMapEntries) - Constructor for class com.hazelcast.replicatedmap.impl.operation.PutAllOperation
 
PutAllOperationFactory - Class in com.hazelcast.replicatedmap.impl.operation
Factory class for PutAllOperation.
PutAllOperationFactory() - Constructor for class com.hazelcast.replicatedmap.impl.operation.PutAllOperationFactory
 
PutAllOperationFactory(String, ReplicatedMapEntries) - Constructor for class com.hazelcast.replicatedmap.impl.operation.PutAllOperationFactory
 
PutAllPartitionAwareOperationFactory - Class in com.hazelcast.map.impl.operation
Inserts the MapEntries for all partitions of a member via locally invoked PutAllOperation.
PutAllPartitionAwareOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.PutAllPartitionAwareOperationFactory
 
PutAllPartitionAwareOperationFactory(String, int[], MapEntries[]) - Constructor for class com.hazelcast.map.impl.operation.PutAllPartitionAwareOperationFactory
 
putAllToList(Collection<Map.Entry<Data, Data>>) - Method in class com.hazelcast.map.impl.MapEntries
 
putAllToMap(SerializationService, Map<K, V>) - Method in class com.hazelcast.map.impl.MapEntries
 
putAllVisitSerializedKeys(MapEntries[]) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
putAsync(K, V) - Method in interface com.hazelcast.cache.ICache
Asynchronously associates the specified value with the specified key in the cache.
putAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Asynchronously associates the specified value with the specified key in the cache using a custom ExpiryPolicy.
putAsync(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
 
putAsync(K, V, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.CacheProxy
 
putAsync(K, V) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
putAsync(K, V, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
putAsync(K, V) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
putAsync(K, V, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
putAsync(K, V) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
putAsync(K, V, long, TimeUnit) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
putAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
putAsync(K, V) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
putAsync(K, V, long, TimeUnit) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
putAsync(K, V, ExpiryPolicy) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
putAsync(K, V) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
putAsync(K, V, long, TimeUnit) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
putAsync(K, V, ExpiryPolicy) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
putAsync(K, V) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
putAsync(K, V, long, TimeUnit) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
putAsync(K, V, ExpiryPolicy) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
putAsync(K, V) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
putAsync(K, V, long, TimeUnit) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
putAsync(K, V, ExpiryPolicy) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
putAsync(K, V) - Method in interface com.hazelcast.map.IMap
Asynchronously puts the given key and value.
putAsync(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Asynchronously puts the given key and value into this map with a given TTL (time to live) value.
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Asynchronously puts the given key and value into this map with a given TTL (time to live) value and max idle time value.
putAsync(K, V) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
putAsync(K, V, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
putAsyncInternal(long, TimeUnit, Long, TimeUnit, Object, Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
putAsyncInternal(long, TimeUnit, Long, TimeUnit, Object, Object) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
putAsyncInternal(Object, Data, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
putBackup(int, Callable) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorContainer
 
putBackup(Data, Object, CallerProvenance) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
putBackup(Data, Object, long, long, boolean, CallerProvenance) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
putBackup(Data, Object, CallerProvenance) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
putBackup(Data, Object, long, long, boolean, CallerProvenance) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
PutBackupOperation - Class in com.hazelcast.map.impl.operation
 
PutBackupOperation(String, Data, Data, RecordInfo) - Constructor for class com.hazelcast.map.impl.operation.PutBackupOperation
 
PutBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.PutBackupOperation
 
PutBackupOperation - Class in com.hazelcast.multimap.impl.operations
 
PutBackupOperation() - Constructor for class com.hazelcast.multimap.impl.operations.PutBackupOperation
 
PutBackupOperation(String, Data, Data, long, int) - Constructor for class com.hazelcast.multimap.impl.operations.PutBackupOperation
 
putBackupTxn(Data, Data, long, long, boolean, CallerProvenance, UUID) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
putBackupTxn(Data, Data, long, long, boolean, CallerProvenance, UUID) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
putBoolean(Object, long, boolean) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Puts the supplied boolean value at the supplied offset from the supplied object's base address.
putBoolean(long, boolean) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putBoolean(Object, long, boolean) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putBoolean(long, boolean) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putBoolean(Object, long, boolean) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putBoolean(long, boolean) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Writes the given boolean value to given address.
putBooleanVolatile(Object, long, boolean) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Writes the boolean value as volatile to given object by its offset.
putBooleanVolatile(long, boolean) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Writes the boolean value as volatile to given object by its offset.
putBooleanVolatile(long, boolean) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putBooleanVolatile(Object, long, boolean) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putBooleanVolatile(long, boolean) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putBooleanVolatile(Object, long, boolean) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putByte(R, long, byte) - Method in interface com.hazelcast.internal.memory.ByteAccessStrategy
Writes byte to corresponding resource
putByte(Object, long, byte) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Puts the supplied byte value at the supplied offset from the supplied object's base address.
putByte(long, byte) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putByte(Object, long, byte) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putByte(byte[], long, byte) - Method in class com.hazelcast.internal.memory.impl.ByteArrayAccessStrategy
 
putByte(ByteBuffer, long, byte) - Method in class com.hazelcast.internal.memory.impl.ByteBufferAccessStrategy
 
putByte(MemoryAccessor, long, byte) - Method in class com.hazelcast.internal.memory.impl.CustomByteAccessStrategy
 
putByte(long, byte) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putByte(Object, long, byte) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putByte(long, byte) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Writes the given byte value to given address.
putByteVolatile(Object, long, byte) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Writes the byte value as volatile to given object by its offset.
putByteVolatile(long, byte) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Writes the byte value as volatile to given object by its offset.
putByteVolatile(long, byte) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putByteVolatile(Object, long, byte) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putByteVolatile(long, byte) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putByteVolatile(Object, long, byte) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putCacheConfigIfAbsent(CacheConfig) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
putCacheConfigIfAbsent(CacheConfig) - Method in interface com.hazelcast.cache.impl.ICacheService
 
putChar(Object, long, char) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Puts the supplied char value at the supplied offset from the supplied object's base address.
putChar(long, char) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putChar(Object, long, char) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putChar(long, char) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putChar(Object, long, char) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putChar(long, char) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Writes the given char value to given address.
putCharVolatile(Object, long, char) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Writes the char value as volatile to given object by its offset.
putCharVolatile(long, char) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Writes the char value as volatile to given object by its offset.
putCharVolatile(long, char) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putCharVolatile(Object, long, char) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putCharVolatile(long, char) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putCharVolatile(Object, long, char) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putDouble(Object, long, double) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Puts the supplied double value at the supplied offset from the supplied object's base address.
putDouble(long, double) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putDouble(Object, long, double) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putDouble(long, double) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putDouble(Object, long, double) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putDouble(long, double) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Writes the given double value to given address.
putDoubleVolatile(Object, long, double) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Writes the double value as volatile to given object by its offset.
putDoubleVolatile(long, double) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Writes the double value as volatile to given object by its offset.
putDoubleVolatile(long, double) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putDoubleVolatile(Object, long, double) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putDoubleVolatile(long, double) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putDoubleVolatile(Object, long, double) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putEntry(QueryableEntry, Object, Index.OperationSource) - Method in class com.hazelcast.query.impl.AbstractIndex
 
putEntry(QueryableEntry, Object, Index.OperationSource) - Method in interface com.hazelcast.query.impl.Index
Saves the given entry into this index.
putEntry(QueryableEntry, Object, Index.OperationSource) - Method in class com.hazelcast.query.impl.Indexes
Inserts a new queryable entry into this indexes instance or updates the existing one.
putFloat(Object, long, float) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Puts the supplied float value at the supplied offset from the supplied object's base address.
putFloat(long, float) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putFloat(Object, long, float) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putFloat(long, float) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putFloat(Object, long, float) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putFloat(long, float) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Writes the given float value to given address.
putFloatVolatile(Object, long, float) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Writes the float value as volatile to given object by its offset.
putFloatVolatile(long, float) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Writes the float value as volatile to given object by its offset.
putFloatVolatile(long, float) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putFloatVolatile(Object, long, float) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putFloatVolatile(long, float) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putFloatVolatile(Object, long, float) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putFromLoad(Data, Object, Address) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
putFromLoad(Data, Object, long, Address) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
putFromLoad(Data, Object, Address) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Puts key-value pair to map which is the result of a load from map store operation.
putFromLoad(Data, Object, long, Address) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
PutFromLoadAllBackupOperation - Class in com.hazelcast.map.impl.operation
Runs on backups.
PutFromLoadAllBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.PutFromLoadAllBackupOperation
 
PutFromLoadAllBackupOperation(String, List<Data>, boolean) - Constructor for class com.hazelcast.map.impl.operation.PutFromLoadAllBackupOperation
 
PutFromLoadAllOperation - Class in com.hazelcast.map.impl.operation
Puts records to map which are loaded from map store by IMap.loadAll(boolean)
PutFromLoadAllOperation() - Constructor for class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
 
PutFromLoadAllOperation(String, List<Data>, boolean) - Constructor for class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
 
putFromLoadBackup(Data, Object) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
putFromLoadBackup(Data, Object, long) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
putFromLoadBackup(Data, Object) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Puts key-value pair to map which is the result of a load from map store operation on backup.
putFromLoadBackup(Data, Object, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
putIfAbsent(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Associates the specified key with the given value if and only if there is not yet a mapping defined for the specified key.
putIfAbsent(Data, Object, ExpiryPolicy, UUID, boolean, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
putIfAbsent(Data, Object, ExpiryPolicy, UUID, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
putIfAbsent(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
 
putIfAbsent(K, V, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.CacheProxy
 
putIfAbsent(Data, Object, ExpiryPolicy, UUID, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Removes the mapping for a key from this cache if it is present.
putIfAbsent(Data, CacheRecord) - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap
 
putIfAbsent(K, V) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
putIfAbsent(K, V, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
putIfAbsent(K, V) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
putIfAbsent(K, V, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
putIfAbsent(K, V) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
putIfAbsent(K, V) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
putIfAbsent(K, V) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
putIfAbsent(K, V) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
putIfAbsent(K, V) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
putIfAbsent(K, V) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
putIfAbsent(String, String, Object, int) - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
putIfAbsent(String, String, Object, int) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
putIfAbsent(long, long) - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
 
putIfAbsent(long, long) - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
 
putIfAbsent(K, V) - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
putIfAbsent(K, V) - Method in interface com.hazelcast.map.BaseMap
If the specified key is not already associated with a value, associate it with the given value.
putIfAbsent(K, V) - Method in interface com.hazelcast.map.IMap
If the specified key is not already associated with a value, associate it with the given value.
putIfAbsent(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Puts an entry into this map with a given TTL (time to live) value, if the specified key is not already associated with a value.
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Puts an entry into this map with a given TTL (time to live) value and max idle time value.
putIfAbsent(K, V) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
putIfAbsent(K, V, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
putIfAbsent(String, String, AccumulatorInfo) - Method in interface com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfoSupplier
Adds a new AccumulatorInfo for the query-cache of IMap.
putIfAbsent(String, String, AccumulatorInfo) - Method in class com.hazelcast.map.impl.querycache.accumulator.DefaultAccumulatorInfoSupplier
 
putIfAbsent(Data, Object, long, long, Address) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
putIfAbsent(Data, Object, long, long, Address) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
putIfAbsent(Object, Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
putIfAbsent(Object, Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
putIfAbsent(K, V) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.putIfAbsent(Object, Object).
putIfAbsentAsync(K, V) - Method in interface com.hazelcast.cache.ICache
Asynchronously associates the specified key with the given value if and only if there is not yet a mapping defined for the specified key.
putIfAbsentAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Asynchronously associates the specified key with the given value if and only if there is not yet a mapping defined for the specified key.
putIfAbsentAsync(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
 
putIfAbsentAsync(K, V, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.CacheProxy
 
putIfAbsentAsync(K, V) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
putIfAbsentAsync(K, V, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
putIfAbsentAsync(K, V) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
putIfAbsentAsync(K, V) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
putIfAbsentAsync(K, V) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
putIfAbsentAsync(K, V) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
putIfAbsentAsync(K, V) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
putIfAbsentInternal(long, TimeUnit, Long, TimeUnit, Object, Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
putIfAbsentInternal(long, TimeUnit, Long, TimeUnit, Object, Object) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
putIfAbsentInternal(Object, Data, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
PutIfAbsentMergePolicy<V,T extends MergingValue<V>> - Class in com.hazelcast.spi.merge
Merges data structure entries from source to destination if they don't exist in the destination data structure.
PutIfAbsentMergePolicy() - Constructor for class com.hazelcast.spi.merge.PutIfAbsentMergePolicy
 
PutIfAbsentOperation - Class in com.hazelcast.map.impl.operation
 
PutIfAbsentOperation(String, Data, Data) - Constructor for class com.hazelcast.map.impl.operation.PutIfAbsentOperation
 
PutIfAbsentOperation() - Constructor for class com.hazelcast.map.impl.operation.PutIfAbsentOperation
 
PutIfAbsentWithExpiryOperation - Class in com.hazelcast.map.impl.operation
 
PutIfAbsentWithExpiryOperation(String, Data, Data, long, long) - Constructor for class com.hazelcast.map.impl.operation.PutIfAbsentWithExpiryOperation
 
PutIfAbsentWithExpiryOperation() - Constructor for class com.hazelcast.map.impl.operation.PutIfAbsentWithExpiryOperation
 
putInt(Object, long, int) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Puts the supplied int value at the supplied offset from the supplied object's base address.
putInt(long, int) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putInt(Object, long, int) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putInt(long, int) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putInt(Object, long, int) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putInt(long, int) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Writes the given int value to given address.
putInternal(long, TimeUnit, Long, TimeUnit, Object, Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
putInternal(long, TimeUnit, Long, TimeUnit, Object, Object) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
putInternal(Object, Data, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
putInternal(Data, Object, long, long, UUID, boolean, boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
putInternal(Data, Data, int) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
putIntVolatile(Object, long, int) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Writes the int value as volatile to given object by its offset.
putIntVolatile(long, int) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Writes the int value as volatile to given object by its offset.
putIntVolatile(long, int) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putIntVolatile(Object, long, int) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putIntVolatile(long, int) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putIntVolatile(Object, long, int) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putKey(long, long, long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray12byteKeyImpl
 
putKey(long, long, long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray8byteKeyImpl
 
putKey(long, long, long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
putListenerIfAbsent(CacheEntryListenerConfiguration, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheSyncListenerCompleter
 
putLocalCacheStats(String, LocalCacheStats) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
putLocalExecutorStats(String, LocalExecutorStats) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
putLocalFlakeIdStats(String, LocalFlakeIdGeneratorStats) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
putLocalMapStats(String, LocalMapStats) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
putLocalMultiMapStats(String, LocalMultiMapStats) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
putLocalPNCounterStats(String, LocalPNCounterStats) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
putLocalQueueStats(String, LocalQueueStats) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
putLocalReliableTopicStats(String, LocalTopicStats) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
putLocalReplicatedMapStats(String, LocalReplicatedMapStats) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
putLocalTopicStats(String, LocalTopicStats) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
putLocalWanStats(String, LocalWanStats) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
putLong(Object, long, long) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Puts the supplied long value at the supplied offset from the supplied object's base address.
putLong(long, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putLong(Object, long, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putLong(long, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putLong(Object, long, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putLong(long, long) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Writes the given long value to given address.
putLongVolatile(Object, long, long) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Writes the long value as volatile to given object by its offset.
putLongVolatile(long, long) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Writes the long value as volatile to given object by its offset.
putLongVolatile(long, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putLongVolatile(Object, long, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putLongVolatile(long, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putLongVolatile(Object, long, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putManagedExecutor(String, ManagedExecutorDTO) - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
 
putObject(Object, long, Object) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Puts the supplied object reference at the supplied offset from the supplied object's base address.
putObject(Object, long, Object) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putObject(Object, long, Object) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putObjectVolatile(Object, long, Object) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Puts the referenced object to given owner object as volatile by its offset.
putObjectVolatile(Object, long, Object) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putObjectVolatile(Object, long, Object) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
PutOperation - Class in com.hazelcast.map.impl.operation
 
PutOperation() - Constructor for class com.hazelcast.map.impl.operation.PutOperation
 
PutOperation(String, Data, Data) - Constructor for class com.hazelcast.map.impl.operation.PutOperation
 
PutOperation - Class in com.hazelcast.multimap.impl.operations
 
PutOperation() - Constructor for class com.hazelcast.multimap.impl.operations.PutOperation
 
PutOperation(String, Data, long, Data, int) - Constructor for class com.hazelcast.multimap.impl.operations.PutOperation
 
PutOperation - Class in com.hazelcast.replicatedmap.impl.operation
Puts a key to the replicated map.
PutOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.PutOperation
 
PutOperation(String, Data, Data) - Constructor for class com.hazelcast.replicatedmap.impl.operation.PutOperation
 
PutOperation(String, Data, Data, long) - Constructor for class com.hazelcast.replicatedmap.impl.operation.PutOperation
 
putOrderedInt(Object, long, int) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Puts the given int value as ordered to the CPU write buffer based by the given object at the given offset.
putOrderedInt(long, int) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Puts the given int value as ordered to the CPU write buffer based in the given object at the given offset.
putOrderedInt(long, int) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putOrderedInt(Object, long, int) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putOrderedInt(long, int) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putOrderedInt(Object, long, int) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putOrderedLong(Object, long, long) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Puts the given long value as ordered to the CPU write buffer based by the given object at the given offset.
putOrderedLong(long, long) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Puts the given long value as ordered to the CPU write buffer based in the given object at the given offset.
putOrderedLong(long, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putOrderedLong(Object, long, long) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putOrderedLong(long, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putOrderedLong(Object, long, long) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putOrderedObject(Object, long, Object) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Puts the given referenced object as ordered to the CPU write buffer based by the given owner object at the given offset.
putOrderedObject(long, Object) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Puts the given referenced object as ordered to the CPU write buffer based by the given owner object at the given offset.
putOrderedObject(long, Object) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putOrderedObject(Object, long, Object) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putOrderedObject(long, Object) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putOrderedObject(Object, long, Object) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putRecord(Data, CacheRecord, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
putRecord(Data, CacheRecord, boolean) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Associates the specified record with the specified key.
putRecord(K, R) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
putRecord(K, R) - Method in class com.hazelcast.internal.nearcache.impl.store.BaseHeapNearCacheRecordStore
 
putRecord(Data, Record) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
putRecord(Data, R) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Puts a data key and a record value to record-store.
putRecords(Collection<RecordMigrationInfo>, long) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
putRecords(Collection<RecordMigrationInfo>, long) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
PutRemoteTransactionBackupOperation - Class in com.hazelcast.transaction.impl.xa.operations
 
PutRemoteTransactionBackupOperation() - Constructor for class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionBackupOperation
 
PutRemoteTransactionBackupOperation(List<TransactionLogRecord>, UUID, SerializableXID, UUID, long, long) - Constructor for class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionBackupOperation
 
PutRemoteTransactionOperation - Class in com.hazelcast.transaction.impl.xa.operations
 
PutRemoteTransactionOperation() - Constructor for class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionOperation
 
PutRemoteTransactionOperation(Collection<TransactionLogRecord>, UUID, SerializableXID, UUID, long, long) - Constructor for class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionOperation
 
putResult(int, Object) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorContainer
 
PutResultBackupOperation - Class in com.hazelcast.durableexecutor.impl.operations
 
PutResultBackupOperation() - Constructor for class com.hazelcast.durableexecutor.impl.operations.PutResultBackupOperation
 
PutResultBackupOperation(String, int, Object) - Constructor for class com.hazelcast.durableexecutor.impl.operations.PutResultBackupOperation
 
PutResultOperation - Class in com.hazelcast.durableexecutor.impl.operations
 
PutResultOperation() - Constructor for class com.hazelcast.durableexecutor.impl.operations.PutResultOperation
 
PutResultOperation(String, int, Object) - Constructor for class com.hazelcast.durableexecutor.impl.operations.PutResultOperation
 
PUTS - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
puts - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
putShort(Object, long, short) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
Puts the supplied short value at the supplied offset from the supplied object's base address.
putShort(long, short) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putShort(Object, long, short) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putShort(long, short) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putShort(Object, long, short) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putShort(long, short) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Writes the given short value to given address.
putShortVolatile(Object, long, short) - Method in interface com.hazelcast.internal.memory.ConcurrentHeapMemoryAccessor
Writes the short value as volatile to given object by its offset.
putShortVolatile(long, short) - Method in interface com.hazelcast.internal.memory.ConcurrentMemoryAccessor
Writes the short value as volatile to given object by its offset.
putShortVolatile(long, short) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putShortVolatile(Object, long, short) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
putShortVolatile(long, short) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putShortVolatile(Object, long, short) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
putTimeTakenNanos - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
putToRecord(CollectionTxnOperation) - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
 
putTransaction(XATransaction) - Method in class com.hazelcast.transaction.impl.xa.XAService
 
putTransient(K, V, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
putTransient(K, V, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
putTransient(K, V, long, TimeUnit) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
putTransient(K, V, long, TimeUnit) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
putTransient(K, V, long, TimeUnit) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
putTransient(K, V, long, TimeUnit) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
putTransient(K, V, long, TimeUnit) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
putTransient(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Same as IMap.put(Object, Object, long, TimeUnit) except that the map store, if defined, will not be called to load/store/persist the entry.
putTransient(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Same as IMap.put(Object, Object, long, TimeUnit) except that the map store, if defined, will not be called to load/store/persist the entry.
putTransient(K, V, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
putTransient(K, V, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
putTransient(Data, Object, long, long) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
putTransient(Data, Object, long, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
PutTransientBackupOperation - Class in com.hazelcast.map.impl.operation
 
PutTransientBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.PutTransientBackupOperation
 
PutTransientBackupOperation(String, Data, Data, RecordInfo) - Constructor for class com.hazelcast.map.impl.operation.PutTransientBackupOperation
 
putTransientInternal(long, TimeUnit, Long, TimeUnit, Object, Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
putTransientInternal(long, TimeUnit, Long, TimeUnit, Object, Object) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
putTransientInternal(Object, Data, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
PutTransientOperation - Class in com.hazelcast.map.impl.operation
 
PutTransientOperation() - Constructor for class com.hazelcast.map.impl.operation.PutTransientOperation
 
PutTransientOperation(String, Data, Data) - Constructor for class com.hazelcast.map.impl.operation.PutTransientOperation
 
PutTransientWithExpiryOperation - Class in com.hazelcast.map.impl.operation
 
PutTransientWithExpiryOperation() - Constructor for class com.hazelcast.map.impl.operation.PutTransientWithExpiryOperation
 
PutTransientWithExpiryOperation(String, Data, Data, long, long) - Constructor for class com.hazelcast.map.impl.operation.PutTransientWithExpiryOperation
 
PutWithExpiryOperation - Class in com.hazelcast.map.impl.operation
 
PutWithExpiryOperation() - Constructor for class com.hazelcast.map.impl.operation.PutWithExpiryOperation
 
PutWithExpiryOperation(String, Data, Data, long, long) - Constructor for class com.hazelcast.map.impl.operation.PutWithExpiryOperation
 
putWithVersion(Object, Object, long, TimeUnit, boolean, long) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
putWithVersion(Object, Object, long, TimeUnit, boolean, long) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
PYTHON - Static variable in class com.hazelcast.client.impl.ClientTypes
PYTHON client protocol ID
PYTHON_PICKLE_SERIALIZATION_TYPE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
 

Q

QUERY - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
query(Object, QueryPolicy) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Executes the given operation on Raft group depending on the QueryPolicy
query(Object, QueryPolicy) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
query(CPGroupId, RaftOp, QueryPolicy) - Method in class com.hazelcast.cp.internal.RaftInvocationManager
 
query - Variable in class com.hazelcast.map.impl.iterator.AbstractMapQueryPartitionIterator
 
QUERY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
Query - Class in com.hazelcast.map.impl.query
Object representing a Query together with all possible co-variants: like a predicate, iterationType, etc.
Query() - Constructor for class com.hazelcast.map.impl.query.Query
 
Query(String, Predicate, IterationType, Aggregator, Projection) - Constructor for class com.hazelcast.map.impl.query.Query
 
query(Predicate) - Method in class com.hazelcast.query.impl.Indexes
Performs a query on this indexes instance using the given predicate.
Query.QueryBuilder - Class in com.hazelcast.map.impl.query
 
QUERY_CACHE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
QUERY_EVENT_FILTER - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
QUERY_EXECUTOR - Static variable in interface com.hazelcast.spi.impl.executionservice.ExecutionService
Name of the query executor.
QUERY_MAX_LOCAL_PARTITION_LIMIT_FOR_PRE_CHECK - Static variable in class com.hazelcast.spi.properties.GroupProperty
Maximum value of local partitions to trigger local pre-check for Predicates.alwaysTrue() predicate query operations on maps.
QUERY_OPERATION - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
QUERY_OPTIMIZER_TYPE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Type of Query Optimizer.
QUERY_PARTITION - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
QUERY_PREDICATE_PARALLEL_EVALUATION - Static variable in class com.hazelcast.spi.properties.GroupProperty
Run Query Evaluations for multiple partitions in parallel.
QUERY_RESULT - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
QUERY_RESULT_ROW - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
QUERY_RESULT_SIZE_EXCEEDED - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
QUERY_RESULT_SIZE_LIMIT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Result size limit for query operations on maps.
QueryableEntriesSegment - Class in com.hazelcast.query.impl
Holder class for a collection of queried entries and the index from which new items can be fetched.
QueryableEntriesSegment(Collection<QueryableEntry>, int) - Constructor for class com.hazelcast.query.impl.QueryableEntriesSegment
 
QueryableEntry<K,V> - Class in com.hazelcast.query.impl
This abstract class contains methods related to Queryable Entry, which means searched an indexed by SQL query or predicate.
QueryableEntry() - Constructor for class com.hazelcast.query.impl.QueryableEntry
 
queryCache - Variable in class com.hazelcast.map.impl.querycache.subscriber.AbstractQueryCacheEndToEndConstructor
 
QueryCache<K,V> - Interface in com.hazelcast.map
A concurrent, queryable data structure which is used to cache results of a continuous query executed on an IMap.
QueryCacheConfig - Class in com.hazelcast.config
Contains configuration for QueryCache.
QueryCacheConfig() - Constructor for class com.hazelcast.config.QueryCacheConfig
 
QueryCacheConfig(String) - Constructor for class com.hazelcast.config.QueryCacheConfig
 
QueryCacheConfig(QueryCacheConfig) - Constructor for class com.hazelcast.config.QueryCacheConfig
 
QueryCacheConfigHolder - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
Client protocol adapter for QueryCacheConfig
QueryCacheConfigHolder() - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
QueryCacheConfigHolder(int, int, int, boolean, boolean, boolean, String, String, PredicateConfigHolder, EvictionConfigHolder, List<ListenerConfigHolder>, List<IndexConfig>) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
QueryCacheConfigHolderCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
QueryCacheConfigReadOnly - Class in com.hazelcast.internal.config
Read only QueryCacheConfig
QueryCacheConfigReadOnly(QueryCacheConfig) - Constructor for class com.hazelcast.internal.config.QueryCacheConfigReadOnly
 
queryCacheConfigs - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
configurations for query caches on this map
QueryCacheConfigurator - Interface in com.hazelcast.map.impl.querycache
QueryCacheConfig supplier abstraction.
QueryCacheContext - Interface in com.hazelcast.map.impl.querycache
A global context which contains all sub-contexts which are responsible for all QueryCache life-cycle management phases.
QueryCacheEndToEndConstructor - Interface in com.hazelcast.map.impl.querycache.subscriber
Constructor which is used to construct all parts/sides of a QueryCache system on nodes or on clients.
QueryCacheEndToEndProvider<K,V> - Class in com.hazelcast.map.impl.querycache.subscriber
Provides construction of whole QueryCache sub-system.
QueryCacheEndToEndProvider(ContextMutexFactory) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.QueryCacheEndToEndProvider
 
QueryCacheEventData - Interface in com.hazelcast.map.impl.querycache.event
Event data contract which is sent to subscriber side.
QueryCacheEventDataBuilder - Class in com.hazelcast.map.impl.querycache.event
Builder for creating a serializable event data for query cache system.
QueryCacheEventDataCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
QueryCacheEventListenerAdapters - Class in com.hazelcast.map.impl.querycache.subscriber
Responsible for creating QueryCache specific implementations of listeners.
queryCacheEventPublisher - Variable in class com.hazelcast.map.impl.event.MapEventPublisherImpl
 
QueryCacheEventPublisher - Class in com.hazelcast.map.impl.event
Handles publishing of map events to continuous query caches
QueryCacheEventPublisher(FilteringStrategy, QueryCacheContext, InternalSerializationService) - Constructor for class com.hazelcast.map.impl.event.QueryCacheEventPublisher
 
QueryCacheEventService<E> - Interface in com.hazelcast.map.impl.querycache
Event service abstraction to allow different type of implementations on query cache subscriber and query cache publisher sides.
QueryCacheFactory - Class in com.hazelcast.map.impl.querycache.subscriber
Static factory for simple QueryCache implementations.
QueryCacheFactory() - Constructor for class com.hazelcast.map.impl.querycache.subscriber.QueryCacheFactory
 
QueryCacheListenerAdapter<T> - Interface in com.hazelcast.map.impl.querycache
Marker interface for the listener adapters used to listen QueryCache.
QueryCacheListenerRegistry - Class in com.hazelcast.map.impl.querycache.publisher
Holds IDs of registered listeners which are registered to listen underlying IMap events to feed QueryCache.
QueryCacheListenerRegistry(QueryCacheContext, String) - Constructor for class com.hazelcast.map.impl.querycache.publisher.QueryCacheListenerRegistry
 
QueryCacheNaturalFilteringStrategy - Class in com.hazelcast.map.impl.event
A filtering strategy that preserves the default behavior in most cases, but processes entry events for listeners with predicates to fit with "query cache" concept.
QueryCacheNaturalFilteringStrategy(InternalSerializationService, MapServiceContext) - Constructor for class com.hazelcast.map.impl.event.QueryCacheNaturalFilteringStrategy
 
QueryCacheRecord<V> - Interface in com.hazelcast.map.impl.querycache.subscriber.record
Represents a QueryCache record.
QueryCacheRecordFactory - Interface in com.hazelcast.map.impl.querycache.subscriber.record
Contract for various QueryCacheRecord factories.
QueryCacheRecordHashMap - Class in com.hazelcast.map.impl.querycache.subscriber
Evictable concurrent hash map implementation.
QueryCacheRecordHashMap(SerializationService, int) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordHashMap
 
QueryCacheRecordStore - Interface in com.hazelcast.map.impl.querycache.subscriber
Common contract for implementations which store QueryCacheRecord.
QueryCacheRequest - Class in com.hazelcast.map.impl.querycache.subscriber
Represents a user request for creating a QueryCache.
QueryCacheScheduler - Interface in com.hazelcast.map.impl.querycache
Scheduler abstraction to allow different type of implementations on query cache subscriber and query cache publisher sides.
QueryCacheToListenerMapper - Class in com.hazelcast.client.impl.querycache.subscriber
This class includes mappings for cacheId to its listener-info-collection
QueryCacheUtil - Class in com.hazelcast.map.impl.querycache.utils
Various utility methods used in order to easily access QueryCacheContext internals.
QueryConstants - Enum in com.hazelcast.query
Contains constants for Query.
QueryContext - Class in com.hazelcast.query.impl
Provides the context for queries execution.
QueryContext(Indexes) - Constructor for class com.hazelcast.query.impl.QueryContext
Creates a new query context with the given available indexes.
QueryContext.IndexMatchHint - Enum in com.hazelcast.query.impl
Defines possible index matching hints.
QueryContextProvider - Interface in com.hazelcast.query.impl
Provides query contexts for Indexes to execute queries.
queryCount() - Method in class com.hazelcast.cp.internal.raft.impl.state.QueryState
Returns the number of queries waiting for execution.
QueryEngine - Interface in com.hazelcast.map.impl.query
Responsible for executing queries on the IMap.
QueryEngineImpl - Class in com.hazelcast.map.impl.query
Invokes and orchestrates the query logic returning the final result.
QueryEngineImpl(MapServiceContext) - Constructor for class com.hazelcast.map.impl.query.QueryEngineImpl
 
QueryEntry - Class in com.hazelcast.query.impl
Entry of the Query.
QueryEntry() - Constructor for class com.hazelcast.query.impl.QueryEntry
 
QueryEntry(InternalSerializationService, Data, Object, Extractors) - Constructor for class com.hazelcast.query.impl.QueryEntry
 
queryEntryFactory - Variable in class com.hazelcast.map.impl.MapContainer
 
QueryEntryFactory - Class in com.hazelcast.map.impl.query
 
QueryEntryFactory(CacheDeserializedValues, InternalSerializationService, Extractors) - Constructor for class com.hazelcast.map.impl.query.QueryEntryFactory
 
QueryEventFilter - Class in com.hazelcast.map.impl.query
Event filter which matches map events on a specified entry key and matching a predefined Predicate.
QueryEventFilter() - Constructor for class com.hazelcast.map.impl.query.QueryEventFilter
 
QueryEventFilter(boolean, Data, Predicate) - Constructor for class com.hazelcast.map.impl.query.QueryEventFilter
 
QueryException - Exception in com.hazelcast.query
Exception class for the Query.
QueryException() - Constructor for exception com.hazelcast.query.QueryException
 
QueryException(String) - Constructor for exception com.hazelcast.query.QueryException
 
QueryException(String, Throwable) - Constructor for exception com.hazelcast.query.QueryException
 
QueryException(Throwable) - Constructor for exception com.hazelcast.query.QueryException
 
queryLocally(CPGroupId, RaftOp, QueryPolicy) - Method in class com.hazelcast.cp.internal.RaftInvocationManager
 
QueryOperation - Class in com.hazelcast.map.impl.query
 
QueryOperation() - Constructor for class com.hazelcast.map.impl.query.QueryOperation
 
QueryOperation(Query) - Constructor for class com.hazelcast.map.impl.query.QueryOperation
 
queryOptimizer - Variable in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
 
queryOptimizer - Variable in class com.hazelcast.map.impl.query.QueryRunner
 
QueryOptimizer - Interface in com.hazelcast.query.impl.predicates
Optimizes predicate for faster execution.
QueryOptimizerFactory - Class in com.hazelcast.query.impl.predicates
Creates QueryOptimizer according to HazelcastProperties configuration.
QueryOptimizerFactory.Type - Enum in com.hazelcast.query.impl.predicates
 
QueryPartitionOperation - Class in com.hazelcast.map.impl.query
 
QueryPartitionOperation() - Constructor for class com.hazelcast.map.impl.query.QueryPartitionOperation
 
QueryPartitionOperation(Query) - Constructor for class com.hazelcast.map.impl.query.QueryPartitionOperation
 
QueryPolicy - Enum in com.hazelcast.cp.internal.raft
Policy to query committed Raft state without appending a log entry but in some cases giving up strong consistency guarantees.
QueryResult - Class in com.hazelcast.map.impl.query
Represents a result of the query execution in the form of an iterable collection of rows.
QueryResult() - Constructor for class com.hazelcast.map.impl.query.QueryResult
Constructs an empty result for the purposes of deserialization.
QueryResult(IterationType, Projection, SerializationService, long, boolean) - Constructor for class com.hazelcast.map.impl.query.QueryResult
Constructs an empty result.
QueryResultCollection<E> - Class in com.hazelcast.map.impl.query
 
QueryResultCollection(SerializationService, IterationType, boolean, boolean) - Constructor for class com.hazelcast.map.impl.query.QueryResultCollection
 
QueryResultCollection(SerializationService, IterationType, boolean, boolean, QueryResult) - Constructor for class com.hazelcast.map.impl.query.QueryResultCollection
 
QueryResultProcessor - Class in com.hazelcast.map.impl.query
Responsible for populating QueryResults
QueryResultProcessor(SerializationService) - Constructor for class com.hazelcast.map.impl.query.QueryResultProcessor
 
QueryResultRow - Class in com.hazelcast.map.impl.query
This interfaces provides methods related to entry of the query result.
QueryResultRow() - Constructor for class com.hazelcast.map.impl.query.QueryResultRow
 
QueryResultRow(Data, Data) - Constructor for class com.hazelcast.map.impl.query.QueryResultRow
 
QueryResultSizeExceededException - Exception in com.hazelcast.map
This exception is thrown when a query exceeds a configurable result size limit.
QueryResultSizeExceededException(String) - Constructor for exception com.hazelcast.map.QueryResultSizeExceededException
 
QueryResultSizeExceededException() - Constructor for exception com.hazelcast.map.QueryResultSizeExceededException
 
QueryResultSizeExceededException(int, String) - Constructor for exception com.hazelcast.map.QueryResultSizeExceededException
 
QueryResultSizeLimiter - Class in com.hazelcast.map.impl.query
Responsible for limiting result size of queries.
QueryResultSizeLimiter(MapServiceContext, ILogger) - Constructor for class com.hazelcast.map.impl.query.QueryResultSizeLimiter
 
queryResultSizeLimiter - Variable in class com.hazelcast.map.impl.query.QueryRunner
 
QueryResultUtils - Class in com.hazelcast.map.impl.query
 
queryRound() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendRequest
 
queryRound() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendSuccessResponse
 
queryRound() - Method in class com.hazelcast.cp.internal.raft.impl.dto.InstallSnapshot
 
queryRound() - Method in class com.hazelcast.cp.internal.raft.impl.state.LeaderState
 
queryRound() - Method in class com.hazelcast.cp.internal.raft.impl.state.QueryState
Returns the index of the heartbeat round to execute the currently waiting queries.
QueryRunner - Class in com.hazelcast.map.impl.query
Runs query operations in the calling thread (thus blocking it)
QueryRunner(MapServiceContext, QueryOptimizer, PartitionScanExecutor, ResultProcessorRegistry) - Constructor for class com.hazelcast.map.impl.query.QueryRunner
 
queryState() - Method in class com.hazelcast.cp.internal.raft.impl.state.LeaderState
 
QueryState - Class in com.hazelcast.cp.internal.raft.impl.state
This class is used to keep the queries until a heartbeat round is performed for running queries without appending entries to the Raft log.
QueryState() - Constructor for class com.hazelcast.cp.internal.raft.impl.state.QueryState
 
QueryTask - Class in com.hazelcast.cp.internal.raft.impl.task
QueryTask is executed to query/read Raft state without appending log entry.
QueryTask(RaftNodeImpl, Object, QueryPolicy, InternalCompletableFuture) - Constructor for class com.hazelcast.cp.internal.raft.impl.task.QueryTask
 
queue(int) - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
 
QUEUE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
QUEUE_CONTAINER - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
QUEUE_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
QUEUE_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
QUEUE_EVENT - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
QUEUE_EVENT_FILTER - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
QUEUE_ITEM - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
QUEUE_MERGING_VALUE - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
QUEUE_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
QUEUE_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
QUEUE_REPLICATION - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
QUEUE_SIZE_COMMAND - Static variable in class com.hazelcast.internal.ascii.rest.HttpGetCommandProcessor
 
QUEUE_STORE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
QUEUE_TRANSACTION_LOG_RECORD - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
QueueAddAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds all of the elements in the specified collection to this collection (optional operation).The behavior of this operation is undefined if the specified collection is modified while the operation is in progress.
QueueAddAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueAddAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueAddAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_ADDLISTENER
QueueAddAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueueAddAllMessageTask
 
QueueAddListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds an listener for this collection.
QueueAddListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
QueueAddListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueAddListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueAddListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_ADDLISTENER
QueueAddListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
 
QueueBackupAwareOperation - Class in com.hazelcast.collection.impl.queue.operations
This abstract class contains important methods for all Queue operations.
QueueBackupAwareOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.QueueBackupAwareOperation
 
QueueBackupAwareOperation(String) - Constructor for class com.hazelcast.collection.impl.queue.operations.QueueBackupAwareOperation
 
QueueBackupAwareOperation(String, long) - Constructor for class com.hazelcast.collection.impl.queue.operations.QueueBackupAwareOperation
 
queueCapacity - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddExecutorConfigCodec.RequestParameters
capacity of executor queue.
QueueClearCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes all of the elements from this collection (optional operation).
QueueClearCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueClearCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueClearMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_CLEAR
QueueClearMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueueClearMessageTask
 
QueueCompareAndRemoveAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes all of this collection's elements that are also contained in the specified collection (optional operation).
QueueCompareAndRemoveAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueCompareAndRemoveAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueCompareAndRemoveAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_COMPAREANDREMOVEALL
QueueCompareAndRemoveAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRemoveAllMessageTask
 
QueueCompareAndRetainAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Retains only the elements in this collection that are contained in the specified collection (optional operation).
QueueCompareAndRetainAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueCompareAndRetainAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueCompareAndRetainAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_COMPAREANDRETAINALL
QueueCompareAndRetainAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRetainAllMessageTask
 
QueueConfig - Class in com.hazelcast.config
Contains the configuration for an IQueue.
QueueConfig() - Constructor for class com.hazelcast.config.QueueConfig
 
QueueConfig(String) - Constructor for class com.hazelcast.config.QueueConfig
 
QueueConfig(QueueConfig) - Constructor for class com.hazelcast.config.QueueConfig
 
QueueConfigReadOnly - Class in com.hazelcast.internal.config
Contains the configuration for an IQueue.
QueueConfigReadOnly(QueueConfig) - Constructor for class com.hazelcast.internal.config.QueueConfigReadOnly
 
QueueContainer - Class in com.hazelcast.collection.impl.queue
The QueueContainer contains the actual queue and provides functionalities such as : queue functionalities transactional operation functionalities schedules queue destruction if it is configured to be destroyed once empty
QueueContainer() - Constructor for class com.hazelcast.collection.impl.queue.QueueContainer
The default no-args constructor is only meant for factory usage.
QueueContainer(String) - Constructor for class com.hazelcast.collection.impl.queue.QueueContainer
 
QueueContainer(String, QueueConfig, NodeEngine, QueueService) - Constructor for class com.hazelcast.collection.impl.queue.QueueContainer
 
QueueContainsAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Return true if this collection contains all of the elements in the specified collection.
QueueContainsAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueContainsAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueContainsAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_CONTAINSALL
QueueContainsAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueueContainsAllMessageTask
 
QueueContainsCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns true if this queue contains the specified element.
QueueContainsCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueContainsCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueContainsMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_CONTAINS
QueueContainsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueueContainsMessageTask
 
queueCount() - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Returns the size of the array holding the concurrent queues.
QueueDataSerializerHook - Class in com.hazelcast.collection.impl.queue
A DataSerializerHook for the queue operations and support structures.
QueueDataSerializerHook() - Constructor for class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
QueuedPipe<E> - Interface in com.hazelcast.internal.util.concurrent
Composed interface for concurrent queues and sequenced containers.
QueueDrainMaxSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_DRAINTOMAXSIZE
QueueDrainMaxSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMaxSizeMessageTask
 
QueueDrainMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_DRAINTO
QueueDrainMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMessageTask
 
QueueDrainToCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes all available elements from this queue and adds them to the given collection.
QueueDrainToCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueDrainToCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueDrainToMaxSizeCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes at most the given number of available elements from this queue and adds them to the given collection.
QueueDrainToMaxSizeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueDrainToMaxSizeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueEvent - Class in com.hazelcast.collection.impl.queue
Used for queue-wide events.
QueueEvent() - Constructor for class com.hazelcast.collection.impl.queue.QueueEvent
 
QueueEvent(String, Data, ItemEventType, Address) - Constructor for class com.hazelcast.collection.impl.queue.QueueEvent
 
QueueEventFilter - Class in com.hazelcast.collection.impl.queue
Provides the filtering functionality for Queue events.
QueueEventFilter() - Constructor for class com.hazelcast.collection.impl.queue.QueueEventFilter
 
QueueEventFilter(boolean) - Constructor for class com.hazelcast.collection.impl.queue.QueueEventFilter
 
QueueEvictionProcessor - Class in com.hazelcast.collection.impl.queue
Eviction Processor for the Queue.
QueueEvictionProcessor(NodeEngine) - Constructor for class com.hazelcast.collection.impl.queue.QueueEvictionProcessor
 
QueueIsEmptyCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns true if this collection contains no elements.
QueueIsEmptyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueIsEmptyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueIsEmptyMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_ISEMPTY
QueueIsEmptyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueueIsEmptyMessageTask
 
QueueItem - Class in com.hazelcast.collection.impl.queue
Queue Item.
QueueItem() - Constructor for class com.hazelcast.collection.impl.queue.QueueItem
 
QueueItem(QueueContainer, long, Data) - Constructor for class com.hazelcast.collection.impl.queue.QueueItem
 
QueueIterator<E> - Class in com.hazelcast.collection.impl.queue
Iterator for the Queue.
QueueIterator(Iterator<Data>, SerializationService, boolean) - Constructor for class com.hazelcast.collection.impl.queue.QueueIterator
 
QueueIteratorCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns an iterator over the elements in this collection.
QueueIteratorCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueIteratorCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueIteratorMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_ITERATOR
QueueIteratorMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueueIteratorMessageTask
 
QueueMBean - Class in com.hazelcast.internal.jmx
Management bean for IQueue
QueueMBean(IQueue, ManagementService) - Constructor for class com.hazelcast.internal.jmx.QueueMBean
 
QueueMergeBackupOperation - Class in com.hazelcast.collection.impl.queue.operations
Creates backups for merged queue items after split-brain healing with a SplitBrainMergePolicy.
QueueMergeBackupOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.QueueMergeBackupOperation
 
QueueMergeBackupOperation(String, Collection<QueueItem>) - Constructor for class com.hazelcast.collection.impl.queue.operations.QueueMergeBackupOperation
 
QueueMergeOperation - Class in com.hazelcast.collection.impl.queue.operations
Merges a SplitBrainMergeTypes.QueueMergeTypes for split-brain healing with a SplitBrainMergePolicy.
QueueMergeOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.QueueMergeOperation
 
QueueMergeOperation(String, SplitBrainMergePolicy<Collection<Object>, SplitBrainMergeTypes.QueueMergeTypes>, SplitBrainMergeTypes.QueueMergeTypes) - Constructor for class com.hazelcast.collection.impl.queue.operations.QueueMergeOperation
 
QueueMergingValueImpl - Class in com.hazelcast.spi.impl.merge
QueueMergingValueImpl() - Constructor for class com.hazelcast.spi.impl.merge.QueueMergingValueImpl
 
QueueMergingValueImpl(SerializationService) - Constructor for class com.hazelcast.spi.impl.merge.QueueMergingValueImpl
 
QueueOfferCodec - Class in com.hazelcast.client.impl.protocol.codec
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available.
QueueOfferCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueOfferCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueOfferMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_OFFER
QueueOfferMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueueOfferMessageTask
 
QueueOperation - Class in com.hazelcast.collection.impl.queue.operations
This class contains methods for Queue operations such as AddAllOperation.
QueueOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.QueueOperation
 
QueueOperation(String) - Constructor for class com.hazelcast.collection.impl.queue.operations.QueueOperation
 
QueueOperation(String, long) - Constructor for class com.hazelcast.collection.impl.queue.operations.QueueOperation
 
QueuePeekCodec - Class in com.hazelcast.client.impl.protocol.codec
Retrieves, but does not remove, the head of this queue, or returns null if this queue is empty.
QueuePeekCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueuePeekCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueuePeekMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_PEEK
QueuePeekMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueuePeekMessageTask
 
QueuePermission - Class in com.hazelcast.security.permission
 
QueuePermission(String, String...) - Constructor for class com.hazelcast.security.permission.QueuePermission
 
QueuePollCodec - Class in com.hazelcast.client.impl.protocol.codec
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
QueuePollCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueuePollCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueuePollMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_POLL
QueuePollMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueuePollMessageTask
 
QueueProxyImpl<E> - Class in com.hazelcast.collection.impl.queue
Proxy implementation for the Queue.
QueueProxyImpl(String, QueueService, NodeEngine, QueueConfig) - Constructor for class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
QueuePutCodec - Class in com.hazelcast.client.impl.protocol.codec
Inserts the specified element into this queue, waiting if necessary for space to become available.
QueuePutCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueuePutCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueuePutMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_PUT
QueuePutMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueuePutMessageTask
 
queueRemainingCapacity() - Method in class com.hazelcast.internal.jmx.ManagedExecutorServiceMBean
 
QueueRemainingCapacityCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the number of additional elements that this queue can ideally (in the absence of memory or resource constraints) accept without blocking, or Integer.MAX_VALUE if there is no intrinsic limit.
QueueRemainingCapacityCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueRemainingCapacityCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueRemainingCapacityMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_REMAININGCAPACITY
QueueRemainingCapacityMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueueRemainingCapacityMessageTask
 
QueueRemoveCodec - Class in com.hazelcast.client.impl.protocol.codec
Retrieves and removes the head of this queue.
QueueRemoveCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueRemoveCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueRemoveListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the specified item listener.Returns silently if the specified listener was not added before.
QueueRemoveListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueRemoveListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueRemoveListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_REMOVELISTENER
QueueRemoveListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
 
QueueRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_REMOVE
QueueRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveMessageTask
 
QueueReplicationOperation - Class in com.hazelcast.collection.impl.queue.operations
Replication operation for the Queue.
QueueReplicationOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.QueueReplicationOperation
 
QueueReplicationOperation(Map<String, QueueContainer>, int, int) - Constructor for class com.hazelcast.collection.impl.queue.operations.QueueReplicationOperation
 
QueueService - Class in com.hazelcast.collection.impl.queue
Provides important services via methods for the the Queue such as QueueEvictionProcessor
QueueService(NodeEngine) - Constructor for class com.hazelcast.collection.impl.queue.QueueService
 
queueSize() - Method in class com.hazelcast.internal.jmx.ManagedExecutorServiceMBean
 
queueSize - Variable in class com.hazelcast.internal.management.dto.ManagedExecutorDTO
 
QueueSizeCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the number of elements in this collection.
QueueSizeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueSizeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_SIZE
QueueSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueueSizeMessageTask
 
QueueStore<T> - Interface in com.hazelcast.collection
QueueStore makes a queue backed by a central data store; such as database, disk, etc.
queueStoreConfig - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddQueueConfigCodec.RequestParameters
backing queue store configuration
QueueStoreConfig - Class in com.hazelcast.config
Configuration for the QueueStore.
QueueStoreConfig() - Constructor for class com.hazelcast.config.QueueStoreConfig
 
QueueStoreConfig(QueueStoreConfig) - Constructor for class com.hazelcast.config.QueueStoreConfig
 
QueueStoreConfigHolder - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
Adapter for using QueueStoreConfig in client protocol.
QueueStoreConfigHolder(String, String, Data, Data, Map<String, String>, boolean) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueueStoreConfigHolder
 
QueueStoreConfigHolderCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
QueueStoreConfigReadOnly - Class in com.hazelcast.internal.config
Contains the configuration for an QueueStore.
QueueStoreConfigReadOnly(QueueStoreConfig) - Constructor for class com.hazelcast.internal.config.QueueStoreConfigReadOnly
 
QueueStoreFactory<T> - Interface in com.hazelcast.collection
Creates a new QueueStore.
QueueStoreWrapper - Class in com.hazelcast.collection.impl.queue
Wrapper for the Queue Store.
QueueTakeCodec - Class in com.hazelcast.client.impl.protocol.codec
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
QueueTakeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueTakeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
QueueTakeMessageTask - Class in com.hazelcast.client.impl.protocol.task.queue
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.QueueMessageType#QUEUE_TAKE
QueueTakeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.queue.QueueTakeMessageTask
 
QueueTransactionLogRecord - Class in com.hazelcast.collection.impl.txnqueue
This class contains Transaction log for the Queue.
QueueTransactionLogRecord() - Constructor for class com.hazelcast.collection.impl.txnqueue.QueueTransactionLogRecord
 
QueueTransactionLogRecord(UUID, String, int) - Constructor for class com.hazelcast.collection.impl.txnqueue.QueueTransactionLogRecord
 
QueueTransactionRollbackOperation - Class in com.hazelcast.collection.impl.txnqueue.operations
Transaction Rollback Operation for the Queue.
QueueTransactionRollbackOperation() - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.QueueTransactionRollbackOperation
 
QueueTransactionRollbackOperation(String, UUID) - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.QueueTransactionRollbackOperation
 
QueueUtil - Class in com.hazelcast.internal.util
Utility class for Queues
QueueWaitNotifyKey - Class in com.hazelcast.collection.impl.queue
Wait thread till notify the key.
QueueWaitNotifyKey(String, String) - Constructor for class com.hazelcast.collection.impl.queue.QueueWaitNotifyKey
 
QuickMath - Class in com.hazelcast.internal.util
The class QuickMath contains methods to perform optimized mathematical operations.
QuickSorter - Class in com.hazelcast.internal.util.sort
Base class for QuickSort implementations.
QuickSorter() - Constructor for class com.hazelcast.internal.util.sort.QuickSorter
 
quote(String) - Static method in class com.hazelcast.internal.jmx.ManagementService
 

R

RAFT_GROUP_INFO - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
RAFT_LOCK - Static variable in class com.hazelcast.cp.internal.datastructures.lock.LockDataSerializerHook
 
RAFT_LOCK_OWNERSHIP_STATE - Static variable in class com.hazelcast.cp.internal.datastructures.lock.LockDataSerializerHook
 
RAFT_LOCK_REGISTRY - Static variable in class com.hazelcast.cp.internal.datastructures.lock.LockDataSerializerHook
 
RAFT_PRE_JOIN_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
RAFT_SEMAPHORE - Static variable in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreDataSerializerHook
 
RAFT_SEMAPHORE_REGISTRY - Static variable in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreDataSerializerHook
 
RAFT_SESSION - Static variable in class com.hazelcast.cp.internal.session.RaftSessionServiceDataSerializerHook
 
RAFT_SESSION_REGISTRY - Static variable in class com.hazelcast.cp.internal.session.RaftSessionServiceDataSerializerHook
 
RaftAlgorithmConfig - Class in com.hazelcast.config.cp
Configuration for Hazelcast's implementation of the Raft consensus algorithm
RaftAlgorithmConfig() - Constructor for class com.hazelcast.config.cp.RaftAlgorithmConfig
 
RaftAlgorithmConfig(RaftAlgorithmConfig) - Constructor for class com.hazelcast.config.cp.RaftAlgorithmConfig
 
RaftAtomicValue<T> - Class in com.hazelcast.cp.internal.datastructures.spi.atomic
State-machine implementation of the Raft-based atomic value
RaftAtomicValue(CPGroupId, String) - Constructor for class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValue
 
RaftAtomicValueService<T,V extends RaftAtomicValue<T>,S extends RaftAtomicValueSnapshot<T>> - Class in com.hazelcast.cp.internal.datastructures.spi.atomic
Contains Raft-based atomic value instances, implements snapshotting, and creates proxies
RaftAtomicValueService(NodeEngine) - Constructor for class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueService
 
RaftAtomicValueSnapshot<T> - Class in com.hazelcast.cp.internal.datastructures.spi.atomic
Snapshot of a RaftAtomicValueService state for a Raft group
RaftAtomicValueSnapshot() - Constructor for class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueSnapshot
 
RaftAtomicValueSnapshot(Map<String, T>, Set<String>) - Constructor for class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueSnapshot
 
RaftDataSerializerHook - Class in com.hazelcast.cp.internal.raft.impl
 
RaftDataSerializerHook() - Constructor for class com.hazelcast.cp.internal.raft.impl.RaftDataSerializerHook
 
RaftDataServiceDataSerializerHook - Class in com.hazelcast.cp.internal.datastructures
 
RaftDataServiceDataSerializerHook() - Constructor for class com.hazelcast.cp.internal.datastructures.RaftDataServiceDataSerializerHook
 
RaftDataServiceDescriptorProvider - Class in com.hazelcast.cp.internal.datastructures
Service descriptions of Raft data structures
RaftDataServiceDescriptorProvider() - Constructor for class com.hazelcast.cp.internal.datastructures.RaftDataServiceDescriptorProvider
 
RaftEndpoint - Interface in com.hazelcast.cp.internal.raft.impl
Represents an endpoint that runs the Raft consensus algorithm as a member of a Raft group.
RaftEndpointImpl - Class in com.hazelcast.cp.internal
Represents an endpoint that runs the Raft consensus algorithm as a member of a Raft group.
RaftEndpointImpl() - Constructor for class com.hazelcast.cp.internal.RaftEndpointImpl
 
RaftEndpointImpl(UUID) - Constructor for class com.hazelcast.cp.internal.RaftEndpointImpl
 
RaftGroupCmd - Class in com.hazelcast.cp.internal.raft.command
Internal commands to perform Raft group management tasks.
RaftGroupCmd() - Constructor for class com.hazelcast.cp.internal.raft.command.RaftGroupCmd
 
RaftGroupId - Class in com.hazelcast.cp.internal
Implementation of CPGroupId.
RaftGroupId() - Constructor for class com.hazelcast.cp.internal.RaftGroupId
 
RaftGroupId(String, long, long) - Constructor for class com.hazelcast.cp.internal.RaftGroupId
 
RaftGroupIdCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
RaftGroupMembers - Class in com.hazelcast.cp.internal.raft.impl.state
Immutable container for members of a Raft group with an index identifying membership change's position in the Raft log.
RaftGroupMembers(long, Collection<RaftEndpoint>, RaftEndpoint) - Constructor for class com.hazelcast.cp.internal.raft.impl.state.RaftGroupMembers
 
RaftIntegration - Interface in com.hazelcast.cp.internal.raft.impl
Integration abstraction between Raft state machine and the underlying platform which is responsible for task/operation execution & scheduling, message transportation and failure detection.
RaftInvocation - Class in com.hazelcast.spi.impl.operationservice.impl
A Invocation implementation that realizes an operation invocation on the leader node of the given Raft group.
RaftInvocation(Invocation.Context, RaftInvocationContext, CPGroupId, Operation, int, long, long) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.RaftInvocation
 
RaftInvocationContext - Class in com.hazelcast.spi.impl.operationservice.impl
Contains all static dependencies for a RaftInvocation along with the CP node list.
RaftInvocationContext(ILogger, RaftService) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.RaftInvocationContext
 
RaftInvocationManager - Class in com.hazelcast.cp.internal
Performs invocations to create & destroy Raft groups, commits RaftOp and runs queries on Raft groups.
RaftLog - Class in com.hazelcast.cp.internal.raft.impl.log
RaftLog keeps and maintains Raft log entries and snapshot.
RaftManagedService - Interface in com.hazelcast.cp.internal.datastructures.spi
An interface that can be implemented by a CP data structure service to receive CP Subsystem lifecycle calls
RaftNode - Interface in com.hazelcast.cp.internal.raft.impl
RaftNode maintains the state of a member for a specific Raft group and exposes methods to handle external client requests (such as append requests, queries and membership changes) and internal Raft RPCs (voting, append request, snapshot installing etc).
raftNode - Variable in class com.hazelcast.cp.internal.raft.impl.task.RaftNodeStatusAwareTask
 
RaftNodeAware - Interface in com.hazelcast.cp.internal
A query operation that requires to access RaftNode state can implement this interface.
RaftNodeImpl - Class in com.hazelcast.cp.internal.raft.impl
Implementation of RaftNode.
RaftNodeLifecycleAwareService - Interface in com.hazelcast.cp.internal
Contains methods that are invoked on life cycle changes of a Raft node
RaftNodeMetrics - Class in com.hazelcast.cp.internal
Container object for single RaftNode metrics.
RaftNodeMetrics() - Constructor for class com.hazelcast.cp.internal.RaftNodeMetrics
 
RaftNodeStatus - Enum in com.hazelcast.cp.internal.raft.impl
Represents status of a RaftNode during its lifecycle.
RaftNodeStatusAwareTask - Class in com.hazelcast.cp.internal.raft.impl.task
Base class for tasks need to know current RaftNodeImpl.
RaftNodeStatusAwareTask(RaftNodeImpl) - Constructor for class com.hazelcast.cp.internal.raft.impl.task.RaftNodeStatusAwareTask
 
RaftOp - Class in com.hazelcast.cp.internal
Base operation class for operations to be replicated to and executed on Raft group members.
RaftOp() - Constructor for class com.hazelcast.cp.internal.RaftOp
 
RaftQueryOp - Class in com.hazelcast.cp.internal.operation
The operation that passes a query to leader or a follower of a Raft group.
RaftQueryOp() - Constructor for class com.hazelcast.cp.internal.operation.RaftQueryOp
 
RaftQueryOp(CPGroupId, RaftOp, QueryPolicy) - Constructor for class com.hazelcast.cp.internal.operation.RaftQueryOp
 
RaftRemoteService - Interface in com.hazelcast.cp.internal.datastructures.spi
Creates and destroys CP data structure instances and their proxies
RaftReplicateOp - Class in com.hazelcast.cp.internal.operation
The base class that replicates the given RaftOp to the target Raft group
RaftRole - Enum in com.hazelcast.cp.internal.raft.impl
Represents role of a member in a Raft group.
raftService - Variable in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
RaftService - Class in com.hazelcast.cp.internal
Contains RaftNode instances that run the Raft consensus algorithm for the created CP groups.
RaftService(NodeEngine) - Constructor for class com.hazelcast.cp.internal.RaftService
 
RaftServiceDataSerializerHook - Class in com.hazelcast.cp.internal
 
RaftServiceDataSerializerHook() - Constructor for class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
RaftServiceDescriptorProvider - Class in com.hazelcast.cp.internal
Provides information about internal Raft services.
RaftServiceDescriptorProvider() - Constructor for class com.hazelcast.cp.internal.RaftServiceDescriptorProvider
 
RaftServicePreJoinOp - Class in com.hazelcast.cp.internal.raftop.metadata
If the CP discovery process is completed, new Hazelcast nodes skip the discovery step.
RaftServicePreJoinOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.RaftServicePreJoinOp
 
RaftServicePreJoinOp(boolean, RaftGroupId) - Constructor for class com.hazelcast.cp.internal.raftop.metadata.RaftServicePreJoinOp
 
RaftSessionService - Class in com.hazelcast.cp.internal.session
This service offers a set of abstractions to track liveliness of Hazelcast clients and servers that use (possibly blocking) data structures on the Raft layer, such as locks and semaphores.
RaftSessionService(NodeEngine) - Constructor for class com.hazelcast.cp.internal.session.RaftSessionService
 
RaftSessionServiceDataSerializerHook - Class in com.hazelcast.cp.internal.session
 
RaftSessionServiceDataSerializerHook() - Constructor for class com.hazelcast.cp.internal.session.RaftSessionServiceDataSerializerHook
 
RaftState - Class in com.hazelcast.cp.internal.raft.impl.state
RaftState is the mutable state maintained by Raft state machine on every node in the group.
RaftStateLoader - Interface in com.hazelcast.cp.internal.raft.impl.persistence
Defines the contract of restoring persisted Raft state from storage layer
RaftStateStore - Interface in com.hazelcast.cp.internal.raft.impl.persistence
Defines the contract of the Raft storage.
RaftSystemOperation - Interface in com.hazelcast.cp.internal
Marker interface for all operations used in Raft system.
raiseFlags(int) - Method in class com.hazelcast.internal.nio.Packet
Raises all the flags raised in the argument.
RANDOM_EVICTION_POLICY - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
RandomEvictionPolicy - Class in com.hazelcast.map.eviction
Random eviction policy for an IMap
RandomEvictionPolicy() - Constructor for class com.hazelcast.map.eviction.RandomEvictionPolicy
 
RandomEvictionPolicyComparator - Class in com.hazelcast.internal.eviction.impl.comparator
RandomEvictionPolicyComparator() - Constructor for class com.hazelcast.internal.eviction.impl.comparator.RandomEvictionPolicyComparator
 
RandomLB - Class in com.hazelcast.client.util
A LoadBalancer that selects a random member to route to.
RandomLB() - Constructor for class com.hazelcast.client.util.RandomLB
 
RandomPicker - Class in com.hazelcast.internal.util
User: ahmetmircik Date: 10/7/13 Time: 12:27 PM
RangePredicate - Interface in com.hazelcast.query.impl.predicates
Defines a common contract for range-like predicates.
RangeVisitor - Class in com.hazelcast.query.impl.predicates
Performs range predicates optimization.
RangeVisitor() - Constructor for class com.hazelcast.query.impl.predicates.RangeVisitor
 
REACHED_MAX_SIZE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
reachedMaxCapacity() - Method in interface com.hazelcast.map.impl.querycache.subscriber.InternalQueryCache
Used to quit pre-population when max size is reached.
reachedMaxCapacity() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
ReachedMaxSizeException - Exception in com.hazelcast.map
Exception thrown when a write-behind MapStore rejects to accept a new element.
ReachedMaxSizeException(String) - Constructor for exception com.hazelcast.map.ReachedMaxSizeException
 
read(ObjectDataInput) - Static method in class com.hazelcast.collection.impl.CollectionTxnUtil
 
read(ObjectDataInput) - Method in class com.hazelcast.durableexecutor.impl.TaskRingBuffer
 
read() - Method in interface com.hazelcast.internal.metrics.DoubleGauge
Reads the current available value as a double.
read() - Method in interface com.hazelcast.internal.metrics.LongGauge
Reads the current available value as a long.
read(int) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ArrayBlockingQueueStreamSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ArrayDequeStreamSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ArrayListStreamSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ArrayStreamSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConcurrentHashMapStreamSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConcurrentSkipListMapStreamSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConcurrentSkipListSetStreamSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.BooleanArraySerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.BooleanSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.ByteSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.CharArraySerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.CharSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.DoubleArraySerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.DoubleSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.FloatArraySerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.FloatSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.IntegerArraySerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.IntegerSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.LongArraySerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.LongSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.NullSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.ShortArraySerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.ShortSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.StringArraySerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.StringSerializer
 
read(byte[]) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.TheByteArraySerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.UuidSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.CopyOnWriteArrayListStreamSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.CopyOnWriteArraySetStreamSerializer
 
read(String, ValueCallback) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
read(String, ValueCollector) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
read(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.DelayQueueStreamSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.HashMapStreamSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.HashSetStreamSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.BigDecimalSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.BigIntegerSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.ClassSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.DateSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.EnumSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.ExternalizableSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.HazelcastJsonValueSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.JavaSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.LinkedBlockingQueueStreamSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.LinkedHashMapStreamSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.LinkedHashSetStreamSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.LinkedListStreamSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.LinkedTransferQueueStreamSerializer
 
read() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
read(byte[]) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
read(byte[], int, int) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.PriorityBlockingQueueStreamSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.SynchronousQueueStreamSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.TreeMapStreamSerializer
 
read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.TreeSetStreamSerializer
 
read() - Method in class com.hazelcast.internal.util.BufferingInputStream
 
read(byte[], int, int) - Method in class com.hazelcast.internal.util.BufferingInputStream
 
read(byte[]) - Method in interface com.hazelcast.nio.serialization.ByteArraySerializer
Converts given byte array to object
read(ObjectDataInput) - Method in interface com.hazelcast.nio.serialization.StreamSerializer
Reads object from objectDataInputStream
read(byte[], Class) - Method in interface com.hazelcast.nio.serialization.TypedByteArrayDeserializer
Reads object from objectDataInputStream
read(ObjectDataInput, Class) - Method in interface com.hazelcast.nio.serialization.TypedStreamDeserializer
Reads object from objectDataInputStream
read(String, ValueCallback<T>) - Method in interface com.hazelcast.query.extractor.ValueReader
Read the value of the attribute specified by the path and returns the result via the callback.
read(String, ValueCollector<T>) - Method in interface com.hazelcast.query.extractor.ValueReader
Read the value of the attribute specified by the path and returns the result directly to the collector.
read(long) - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
 
read(long) - Method in interface com.hazelcast.ringbuffer.impl.Ringbuffer
Reads one item from the ringbuffer.
read(long) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Reads one item from the ringbuffer.
READ_AND_RESET_ACCUMULATOR - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
READ_MANY_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
 
READ_ONE_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
 
READ_PERMITTED - Static variable in interface com.hazelcast.internal.nearcache.NearCacheRecord
 
READ_RESULT_SET - Static variable in class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
 
READ_RESULT_SET - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
 
ReadAndResetAccumulatorOperation - Class in com.hazelcast.map.impl.querycache.subscriber.operation
Reads all available items from the accumulator of the partition and resets it.
ReadAndResetAccumulatorOperation() - Constructor for class com.hazelcast.map.impl.querycache.subscriber.operation.ReadAndResetAccumulatorOperation
 
ReadAndResetAccumulatorOperation(String, String) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.operation.ReadAndResetAccumulatorOperation
 
readAsData(long) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
Reads one item from the ring buffer and returns the serialized format.
readAttributeValue(ObjectDataInput) - Static method in class com.hazelcast.internal.nio.IOUtil
 
readBackupData - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
true to enable reading local backup entries, false otherwise
readBackupData(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
This method is called directly by user threads, in other words it is called outside of the partition threads.
readBackupData(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Called when MapConfig.isReadBackupData() is true from MapProxySupport.getInternal(java.lang.Object)
readBatchSize - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReliableTopicConfigCodec.RequestParameters
maximum number of items to read in a batch.
readBoolean(int) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
readBoolean(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readBoolean(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readBoolean() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readBoolean(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readBooleanArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readBooleanArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readBooleanArray() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readBooleanArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readBooleanArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readByte(int) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
readByte(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readByte(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readByte() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readByte(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readByteArray(ObjectDataInput) - Static method in class com.hazelcast.internal.nio.IOUtil
 
readByteArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readByteArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readByteArray() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readByteArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readByteArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readChar(ByteAccessStrategy<R>, R, long, boolean) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readChar(byte[], int, boolean) - Static method in class com.hazelcast.internal.nio.Bits
 
readChar(int) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
readChar(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readChar(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readChar() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readChar(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readCharArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readCharArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readCharArray() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readCharArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readCharArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readCharB(ByteAccessStrategy<R>, R, long) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readCharB(byte[], int) - Static method in class com.hazelcast.internal.nio.Bits
 
readCharL(ByteAccessStrategy<R>, R, long) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readCharL(byte[], int) - Static method in class com.hazelcast.internal.nio.Bits
 
readCollection(ObjectDataInput) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
Reads a collection from the given ObjectDataInput.
readCount - Variable in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalReadCodec.ResponseParameters
TODO DOC
readCount - Variable in class com.hazelcast.client.impl.protocol.codec.MapEventJournalReadCodec.ResponseParameters
TODO DOC
readCount - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferReadManyCodec.ResponseParameters
TODO DOC
readCount() - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
 
readCount() - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
 
readCount() - Method in interface com.hazelcast.ringbuffer.ReadResultSet
Returns the number of items that have been read before filtering.
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.BigDecimalAverageAggregator
 
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.BigDecimalSumAggregator
 
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.BigIntegerAverageAggregator
 
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.BigIntegerSumAggregator
 
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.CountAggregator
 
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.DistinctValuesAggregator
 
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.DoubleAverageAggregator
 
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.DoubleSumAggregator
 
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.FixedSumAggregator
 
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.FloatingPointSumAggregator
 
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.IntegerAverageAggregator
 
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.IntegerSumAggregator
 
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.LongAverageAggregator
 
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.LongSumAggregator
 
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.MaxAggregator
 
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.MaxByAggregator
 
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.MinAggregator
 
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.MinByAggregator
 
readData(ObjectDataInput) - Method in class com.hazelcast.aggregation.impl.NumberAverageAggregator
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.CacheClearResponse
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.CacheEntryIterationResult
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.CacheEventListenerAdaptor
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.CacheEventSet
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.CacheKeyIterationResult
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.CachePartitionEventData
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.event.CachePartitionLostEventFilter
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation.MetaDataResponse
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheNearCacheStateHolder
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.record.CacheDataRecord
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.record.CacheObjectRecord
 
readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.tenantcontrol.CacheDestroyEventContext
 
readData(ObjectDataInput) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
 
readData(ObjectDataInput) - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.DenseHyperLogLogEncoder
 
readData(ObjectDataInput) - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.SparseHyperLogLogEncoder
 
readData(ObjectDataInput) - Method in class com.hazelcast.client.impl.operations.OperationFactoryWrapper
 
readData(ObjectDataInput) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.cluster.Address
 
readData(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.AbstractMember
 
readData(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.VectorClock
 
readData(ObjectDataInput) - Method in class com.hazelcast.cluster.MemberAttributeEvent
 
readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.CollectionEvent
 
readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.CollectionEventFilter
 
readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.CollectionItem
 
readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.TxCollectionItem
 
readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
 
readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.QueueEvent
 
readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.QueueEventFilter
 
readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.QueueItem
 
readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
 
readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.TxQueueItem
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.AttributeConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.CollectionConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.DiscoveryConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.DurableExecutorConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.EntryListenerConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.EventJournalConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.EvictionConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.ExecutorConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.HotRestartConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.IndexConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.ItemListenerConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.ListenerConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MapConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MapStoreConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MaxSizeConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MergePolicyConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MerkleTreeConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.MultiMapConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.NearCacheConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.PNCounterConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.PredicateConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.QueryCacheConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.QueueConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.QueueStoreConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.ReliableTopicConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.ReplicatedMapConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.RingbufferConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.TopicConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.WanConsumerConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.WanReplicationConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.WanReplicationRef
 
readData(ObjectDataInput) - Method in class com.hazelcast.config.WanSyncConfig
 
readData(ObjectDataInput) - Method in class com.hazelcast.console.Echo
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.CPGroupInfo
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.CPGroupSummary
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.CPMemberInfo
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.AbstractAtomicLongOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.AddAndGetOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.AlterOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.ApplyOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.CompareAndSetOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.GetAndAddOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.GetAndSetOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.AbstractAtomicRefOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.ApplyOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.CompareAndSetOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.ContainsOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.SetOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatch
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.AbstractCountDownLatchOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.AwaitOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.CountDownOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.TrySetCountOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.lock.Lock
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.lock.LockEndpoint
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.lock.LockInvocationKey
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.lock.LockOwnershipState
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.GetLockOwnershipStateOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.LockOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.TryLockOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.AcquireInvocationKey
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.AcquirePermitsOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.AvailablePermitsOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.ChangePermitsOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.InitSemaphoreOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.ReleasePermitsOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.Semaphore
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreEndpoint
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueSnapshot
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.BlockingResource
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.operation.ExpireWaitKeysOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKey
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKeyContainer
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.spi.operation.DestroyRaftObjectOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.MembershipChangeSchedule.CPGroupMembershipChange
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.MembershipChangeSchedule
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raft.command.DestroyRaftGroupCmd
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raft.impl.command.UpdateRaftGroupMembersCmd
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendFailureResponse
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendRequest
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendSuccessResponse
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raft.impl.dto.InstallSnapshot
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raft.impl.dto.PreVoteRequest
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raft.impl.dto.PreVoteResponse
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raft.impl.dto.TriggerLeaderElection
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raft.impl.dto.VoteRequest
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raft.impl.dto.VoteResponse
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raft.impl.log.LogEntry
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raft.impl.log.SnapshotEntry
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.RaftEndpointImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.RaftGroupId
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.GetInitialRaftGroupMembersIfCurrentGroupMemberOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.metadata.AddCPMemberOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.metadata.CompleteDestroyRaftGroupsOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.metadata.CompleteRaftGroupMembershipChangesOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.metadata.CreateRaftGroupOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.metadata.ForceDestroyRaftGroupOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetActiveCPMembersOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetActiveRaftGroupByNameOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetActiveRaftGroupIdsOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetDestroyingRaftGroupIdsOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetMembershipChangeScheduleOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetRaftGroupIdsOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetRaftGroupOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.metadata.InitMetadataRaftGroupOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.metadata.RemoveCPMemberOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.metadata.TriggerDestroyRaftGroupOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.NotifyTermChangeOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.snapshot.RestoreSnapshotOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.session.CPSessionInfo
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.session.operation.CloseInactiveSessionsOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.session.operation.CloseSessionOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.session.operation.CreateSessionOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.session.operation.ExpireSessionsOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.session.operation.GenerateThreadIdOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.session.operation.GetSessionsOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.session.operation.HeartbeatSessionOp
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.session.SessionResponse
 
readData(ObjectDataInput) - Method in class com.hazelcast.cp.internal.UnsafeModePartitionState
 
readData(ObjectDataInput) - Method in class com.hazelcast.executor.impl.RunnableAdapter
 
readData(ObjectDataInput) - Method in class com.hazelcast.instance.EndpointQualifier
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.ascii.rest.RestValue
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.BindMessage
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.ClusterStateChange
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.ClusterStateTransactionLogRecord
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.ConfigCheck
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.ExtendedBindMessage
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.JoinRequest
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.MembersView
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.MembersViewMetadata
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.SplitBrainJoinMessage
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.MemberInfo
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.crdt.pncounter.operations.CRDTTimestampedLong
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.journal.DeserializingEntry
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.journal.EventJournalInitialSubscriberState
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.management.dto.MapConfigDTO
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.management.dto.PermissionConfigDTO
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.CacheBrowserEntryView
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.GetCacheEntryViewEntryProcessor
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.BatchNearCacheInvalidation
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidation
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.SingleNearCacheInvalidation
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.partition.MigrationInfo
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.partition.MigrationStateImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.partition.NonFragmentedServiceNamespace
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.partition.PartitionLostEventImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.partition.PartitionReplica
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.partition.PartitionRuntimeState
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.partition.ReplicaFragmentMigrationState
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.partition.ReplicaMigrationEventImpl
 
readData() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.services.DistributedObjectNamespace
 
readData(ObjectDataInput) - Method in class com.hazelcast.internal.usercodedeployment.impl.ClassData
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.eviction.LFUEvictionPolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.EntryEventFilter
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.EntryRemovingProcessor
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.event.EntryEventData
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.event.MapEventData
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.event.MapPartitionEventData
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.EventListenerFilter
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.iterator.AbstractCursor
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.LazyMapEntry
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.MapEntries
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.MapKeySet
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.MapPartitionLostEventFilter
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.MapValueCollection
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.MerkleTreeNodeEntries
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.nearcache.invalidation.UuidFilter
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.AddIndexOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.ClearOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.ContainsValueOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.EvictAllOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.IsEmptyOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.IsPartitionLoadedOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.KeyLoadStatusOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapFlushOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapGetAllOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapGetInvalidationMetaDataOperation.MetaDataResponse
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapLoadAllOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapNearCacheStateHolder
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapReplicationStateHolder
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MergeOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation.InterceptorInfo
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PutAllPartitionAwareOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.SizeOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.WriteBehindStateHolder
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.query.AggregationResult
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.query.Query
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.query.QueryEventFilter
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.query.QueryResult
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.query.QueryResultRow
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.query.ResultSegment
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.query.Target
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.querycache.event.BatchEventData
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.querycache.event.LocalCacheWideEventData
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.querycache.event.LocalEntryEventData
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.MadePublishableOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.record.RecordInfo
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.record.RecordReplicationInfo
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.MapTransactionLogRecord
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.VersionedValue
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
 
readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.wan.WanMapEntryView
 
readData(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.MultiMapEventFilter
 
readData(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.MultiMapMergeContainer
 
readData(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.MultiMapRecord
 
readData(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.EntrySetResponse
 
readData(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
 
readData(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
 
readData() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readData(ObjectDataInput) - Method in interface com.hazelcast.nio.serialization.DataSerializable
Reads fields from the input stream
readData(ObjectDataInput) - Method in class com.hazelcast.partition.PartitionAwareKey
 
readData(ObjectDataInput) - Method in class com.hazelcast.projection.impl.IdentityProjection
 
readData(ObjectDataInput) - Method in class com.hazelcast.projection.impl.MultiAttributeProjection
 
readData(ObjectDataInput) - Method in class com.hazelcast.projection.impl.SingleAttributeProjection
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.CompositeValue
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.MapIndexInfo
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.AndPredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.FalsePredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.InPredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.InstanceOfPredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.LikePredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.NotEqualPredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.NotPredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.OrPredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.PartitionPredicateImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.RegexPredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.SqlPredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.TruePredicate
 
readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.MergeOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.PutAllOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.VersionResponsePair
 
readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
readData(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
 
readData(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.HashMapAdapter
 
readData(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.NamedTaskDecorator
 
readData(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnPartitionOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledRunnableAdapter
 
readData(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskDescriptor
 
readData(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskResult
 
readData(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskStatisticsImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.TaskDefinition
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventEnvelope
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.eventservice.impl.TrueEventFilter
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.merge.AbstractCollectionMergingValueImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.merge.AbstractMergingEntryImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.merge.AbstractMergingValueImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.merge.AbstractSplitBrainMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.merge.RingbufferMergingValueImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.BinaryOperationFactory
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation.PartitionResponse
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.ErrorResponse
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.NormalResponse
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.OperationControl
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectEventPacket
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.SerializableList
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.tenantcontrol.NoopTenantControl
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
 
readData(ObjectDataInput) - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicMessage
 
readData(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.xa.SerializableXID
 
readData(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.xa.XATransactionDTO
 
readData(ObjectDataInput) - Method in class com.hazelcast.transaction.TransactionOptions
 
readData(ObjectDataInput) - Method in class com.hazelcast.version.MemberVersion
 
readData(ObjectDataInput) - Method in class com.hazelcast.version.Version
 
readDataAsObject() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readDataAsObject() - Method in interface com.hazelcast.nio.ObjectDataInput
Reads to stored Data as an object instead of a Data instance.
readDouble(ByteAccessStrategy<R>, R, long, boolean) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readDouble(int) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
readDouble(ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
readDouble(int, ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
readDouble(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readDouble(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readDouble() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readDouble(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readDoubleArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readDoubleArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readDoubleArray() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readDoubleArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readDoubleArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readDoubleB(ByteAccessStrategy<R>, R, long) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readDoubleL(ByteAccessStrategy<R>, R, long) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readFactories(ObjectDataInput) - Method in class com.hazelcast.cache.impl.PreJoinCacheConfig
 
readFactories(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
 
readFloat(ByteAccessStrategy<R>, R, long, boolean) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readFloat(int) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
readFloat(ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
readFloat(int, ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
readFloat(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readFloat(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readFloat() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readFloat(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readFloatArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readFloatArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readFloatArray() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readFloatArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readFloatArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readFloatB(ByteAccessStrategy<R>, R, long) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readFloatL(ByteAccessStrategy<R>, R, long) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readFrom(ByteBuffer, boolean) - Method in class com.hazelcast.client.impl.protocol.ClientMessageReader
 
readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.BulkGetCommand
 
readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.DeleteCommand
 
readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.ErrorCommand
 
readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.GetCommand
 
readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.IncrementCommand
 
readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.SetCommand
 
readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.SimpleCommand
 
readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.StatsCommand
 
readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.TouchCommand
 
readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.VersionCommand
 
readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.NoOpCommand
 
readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
 
readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.rest.HttpPostCommand
POST /path HTTP/1.0 User-Agent: HTTPTool/1.0 Content-TextCommandType: application/x-www-form-urlencoded Content-Length: 45 <next_line> <next_line> byte[45] <next_line>
readFrom(ByteBuffer) - Method in interface com.hazelcast.internal.ascii.TextCommand
 
readFrom(Reader) - Static method in class com.hazelcast.internal.json.JsonArray
Deprecated.
readFrom(String) - Static method in class com.hazelcast.internal.json.JsonArray
Deprecated.
readFrom(Reader) - Static method in class com.hazelcast.internal.json.JsonObject
Deprecated.
readFrom(String) - Static method in class com.hazelcast.internal.json.JsonObject
Deprecated.
readFrom(Reader) - Static method in class com.hazelcast.internal.json.JsonValue
Deprecated.
Use Json.parse(Reader) instead
readFrom(String) - Static method in class com.hazelcast.internal.json.JsonValue
Deprecated.
Use Json.parse(String) instead
readFrom(ByteBuffer) - Method in class com.hazelcast.internal.nio.PacketIOHelper
Reads the packet data from the supplied ByteBuffer.
readFrom(DataInput) - Static method in enum com.hazelcast.internal.partition.MigrationInfo.MigrationStatus
 
readFrom(DataInput) - Static method in enum com.hazelcast.spi.partition.MigrationEndpoint
 
readFromEventJournal(long, int, int, int, Predicate<? super EventJournalCacheEvent<K, V>>, Function<? super EventJournalCacheEvent<K, V>, ? extends T>) - Method in class com.hazelcast.cache.impl.CacheProxy
 
readFromEventJournal(long, int, int, int, Predicate<? super EventJournalCacheEvent<K, V>>, Function<? super EventJournalCacheEvent<K, V>, ? extends T>) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
readFromEventJournal(long, int, int, int, Predicate<? super EventJournalMapEvent<K, V>>, Function<? super EventJournalMapEvent<K, V>, ? extends T>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
readFromEventJournal(long, int, int, int, Predicate<? super E>, Function<? super E, ? extends T>) - Method in interface com.hazelcast.internal.journal.EventJournalReader
Reads from the event journal.
readFromEventJournal(long, int, int, int, Predicate<? super EventJournalMapEvent<K, V>>, Function<? super EventJournalMapEvent<K, V>, ? extends T>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
Reads from the event journal.
readFully(InputStream, byte[]) - Static method in class com.hazelcast.internal.nio.IOUtil
Fills a buffer from an InputStream.
readFully(byte[]) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readFully(byte[], int, int) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readFullyOrNothing(InputStream, byte[]) - Static method in class com.hazelcast.internal.nio.IOUtil
Fills a buffer from an InputStream.
readInt(ByteAccessStrategy<R>, R, long, boolean) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readInt(byte[], int, boolean) - Static method in class com.hazelcast.internal.nio.Bits
 
readInt(int) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
readInt(ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
readInt(int, ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
readInt(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readInt(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readInt() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readInt(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readIntArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readIntArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readIntArray() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readIntArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readIntArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readIntB(ByteAccessStrategy<R>, R, long) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readIntB(byte[], int) - Static method in class com.hazelcast.internal.nio.Bits
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalReadOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.AddCacheConfigOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
Deprecated.
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheDestroyOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheEntryIteratorOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheExpireBatchBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheGetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheKeyIteratorOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CachePutBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheSetExpiryPolicyBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheSetExpiryPolicyOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.KeyBasedCacheOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.MutatingCacheOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.OnJoinCacheOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cardinality.impl.operations.AbstractCardinalityEstimatorOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cardinality.impl.operations.AggregateBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cardinality.impl.operations.AggregateOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cardinality.impl.operations.MergeBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cardinality.impl.operations.MergeOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cardinality.impl.operations.ReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionClearBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionCompareAndRemoveOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionContainsOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionMergeBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionMergeOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.list.operations.ListAddAllOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.list.operations.ListAddOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.list.operations.ListGetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.list.operations.ListIndexOfOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.list.operations.ListRemoveOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.list.operations.ListReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.list.operations.ListSetBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.list.operations.ListSetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.list.operations.ListSubOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.AddAllBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.AddAllOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.ClearBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.ContainsOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.DrainBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.DrainOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.OfferBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.PollBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.QueueMergeBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.QueueMergeOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.QueueReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.RemoveBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.RemoveOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.set.operations.SetReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveAddOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveRemoveOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTransactionRollbackOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.BaseTxnQueueOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.QueueTransactionRollbackOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPeekOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.operation.ChangeRaftGroupMembershipOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.operation.DefaultRaftReplicateOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.operation.integration.AppendFailureResponseOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.operation.integration.AppendRequestOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.operation.integration.AppendSuccessResponseOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.operation.integration.AsyncRaftOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.operation.integration.InstallSnapshotOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.operation.integration.PreVoteRequestOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.operation.integration.PreVoteResponseOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.operation.integration.TriggerLeaderElectionOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.operation.integration.VoteRequestOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.operation.integration.VoteResponseOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.operation.RaftQueryOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.operation.RaftReplicateOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.operation.RestartCPMemberOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.operation.TransferLeadershipOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.operation.unsafe.AbstractUnsafeRaftOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.operation.unsafe.UnsafeSnapshotReplicationOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.operation.unsafe.UnsafeStateReplicationOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.metadata.CreateRaftNodeOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.metadata.DestroyRaftNodesOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.metadata.PublishActiveCPMembersOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cp.internal.raftop.metadata.RaftServicePreJoinOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.durableexecutor.impl.operations.DisposeResultBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.durableexecutor.impl.operations.DisposeResultOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.durableexecutor.impl.operations.PutResultBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.durableexecutor.impl.operations.PutResultOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.durableexecutor.impl.operations.ReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.durableexecutor.impl.operations.RetrieveResultOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.durableexecutor.impl.operations.TaskBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.durableexecutor.impl.operations.TaskOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.BeforeJoinCheckFailureOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.CommitClusterStateOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.ConfigMismatchOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.ExplicitSuspicionOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.FetchMembersViewOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.HeartbeatComplaintOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.HeartbeatOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.JoinRequestOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.LockClusterStateOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.MasterResponseOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.MemberAttributeChangedOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.MembersUpdateOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.MergeClustersOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.OnJoinOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.RollbackClusterStateOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.SplitBrainMergeValidationOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.TriggerExplicitSuspicionOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.WhoisMasterOp
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.crdt.AbstractCRDTReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.crdt.pncounter.operations.AbstractPNCounterOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.crdt.pncounter.operations.AddOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.crdt.pncounter.operations.GetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.dynamicconfig.AddDynamicConfigOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigPreJoinOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.journal.EventJournalReadOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.locksupport.operations.LocalLockCleanupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.locksupport.operations.LockBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.locksupport.operations.LockReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.locksupport.operations.UnlockBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.locksupport.operations.UnlockIfLeaseExpiredOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.locksupport.operations.UnlockOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.longregister.operations.AbstractLongRegisterOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.longregister.operations.AddAndGetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.longregister.operations.AddBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.longregister.operations.GetAndAddOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.longregister.operations.GetAndSetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.longregister.operations.LongRegisterReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.longregister.operations.SetBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.longregister.operations.SetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.management.operation.ScriptExecutorOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.management.operation.SetLicenseOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.management.operation.UpdateManagementCenterUrlOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.management.operation.UpdateMapConfigOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.management.operation.UpdatePermissionConfigOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.metrics.managementcenter.ReadMetricsOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.partition.operation.FinalizeMigrationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.partition.operation.MigrationCommitOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.partition.operation.MigrationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.partition.operation.MigrationRequestOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.partition.operation.PartitionBackupReplicaAntiEntropyOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRequest
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncResponse
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRetryResponse
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.partition.operation.PartitionStateOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.partition.operation.PartitionStateVersionCheckOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.partition.operation.PromotionCommitOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.partition.operation.PublishCompletedMigrationsOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.usercodedeployment.impl.operation.ClassDataFinderOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.usercodedeployment.impl.operation.DeployClassesOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.journal.MapEventJournalReadOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.AddIndexBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.AddIndexOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.AwaitMapFlushOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.ContainsValueOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.DeleteOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.EntryBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.EntryOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.EvictBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.EvictBatchBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.EvictOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.GetAllOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.KeyLoadStatusOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.LoadAllOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.LoadMapOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapFetchEntriesOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapFetchKeysOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapFetchWithQueryOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapFlushBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapGetInvalidationMetaDataOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MergeOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MultipleEntryBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MultipleEntryWithPredicateBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MultipleEntryWithPredicateOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.NotifyMapFlushOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PutAllBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PutAllOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PutIfAbsentWithExpiryOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PutTransientWithExpiryOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PutWithExpiryOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.ReadonlyKeyBasedMapOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.RemoveBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.RemoveFromLoadAllOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.RemoveIfSameOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.SetTtlBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.SetTtlOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.SetWithExpiryOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.query.QueryOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.query.QueryPartitionOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.DestroyQueryCacheOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.MadePublishableOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.PublisherCreateOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.ReadAndResetAccumulatorOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.SetReadCursorOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnDeleteBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnPrepareBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnRollbackBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnSetBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnUnlockBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.AbstractBackupAwareMultiMapOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.AbstractKeyBasedMultiMapOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.MergeBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.MergeOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.MultiMapReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.PutBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.PutOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.RemoveBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnCommitBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnPutBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.CheckReplicaVersionOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsKeyOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsValueOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.EntrySetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.GetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.IsEmptyOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.KeySetOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.MergeOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.PutAllOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.PutOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.RemoveOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateToCallerOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.RequestMapDataOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.SizeOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.SyncReplicatedMapDataOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ValuesOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.AbstractRingBufferOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.AddBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.GenericOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.MergeBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.MergeOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.ReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.AbstractSchedulerOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.CancelTaskBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.CancelTaskOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.DisposeBackupTaskOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.DisposeTaskOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetDelayOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetResultOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetStatisticsOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.IsCanceledOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.IsDoneOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.MergeBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.MergeOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.ReplicationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.ResultReadyNotifyOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.ScheduleTaskBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.ScheduleTaskOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.SyncStateOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.OnJoinRegistrationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.SendEventOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.AbstractLocalOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.AbstractNamedOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.DistributedObjectDestroyOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.InitializeDistributedObjectOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.PostJoinProxyOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.topic.impl.PublishOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.operations.BroadcastTxRollbackOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.operations.PurgeTxBackupLogOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.operations.ReplicateTxBackupLogOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.operations.RollbackTxBackupLogOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionBackupOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.xa.operations.XaReplicationOperation
 
readInternalImpl(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.FinalizeJoinOp
 
readInternalImpl(ObjectDataInput) - Method in class com.hazelcast.internal.cluster.impl.operations.MembersUpdateOp
 
readInternalImpl(ObjectDataInput) - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.DeregistrationOperation
 
readInternalImpl(ObjectDataInput) - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.RegistrationOperation
 
readIntL(ByteAccessStrategy<R>, R, long) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readIntL(byte[], int) - Static method in class com.hazelcast.internal.nio.Bits
 
readIntL(ByteBuffer, int) - Static method in class com.hazelcast.internal.nio.Bits
 
readKeyValueTypes(ObjectDataInput) - Method in class com.hazelcast.cache.impl.PreJoinCacheConfig
 
readKeyValueTypes(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
 
readLine() - Method in interface com.hazelcast.console.LineReader
 
readLine() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
Deprecated.
readList(ObjectDataInput) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
Reads a list from the given ObjectDataInput.
readListenerConfigurations(ObjectDataInput) - Method in class com.hazelcast.cache.impl.PreJoinCacheConfig
 
readListenerConfigurations(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
 
readLocalCPMember() - Method in interface com.hazelcast.cp.internal.persistence.CPMetadataStore
Reads CPMember identity of this member from storage.
readLocalCPMember() - Method in class com.hazelcast.cp.internal.persistence.NopCPMetadataStore
 
readLong(ByteAccessStrategy<R>, R, long, boolean) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readLong(byte[], int, boolean) - Static method in class com.hazelcast.internal.nio.Bits
 
readLong(int) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
readLong(ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
readLong(int, ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
readLong(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readLong(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readLong() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readLong(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readLongArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readLongArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readLongArray() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readLongArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readLongArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readLongAttribute(String, long) - Static method in class com.hazelcast.internal.util.OperatingSystemMXBeanSupport
Reads a long attribute from OperatingSystemMXBean.
readLongB(ByteAccessStrategy<R>, R, long) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readLongB(byte[], int) - Static method in class com.hazelcast.internal.nio.Bits
 
readLongL(ByteAccessStrategy<R>, R, long) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readLongL(byte[], int) - Static method in class com.hazelcast.internal.nio.Bits
 
readMany(ObjectNamespace, int, long, ReadResultSetImpl<InternalEventJournalCacheEvent, T>) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
 
readMany(ObjectNamespace, int, long, ReadResultSetImpl<E, T>) - Method in interface com.hazelcast.internal.journal.EventJournal
Reads events from the journal in batches.
readMany(ObjectNamespace, int, long, ReadResultSetImpl<InternalEventJournalMapEvent, T>) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
 
readMany(long, ReadResultSetImpl) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
Reads multiple items from the ring buffer and adds them to result in the stored format.
readManyAsync(long, int, int, IFunction<E, Boolean>) - Method in class com.hazelcast.client.impl.proxy.ClientRingbufferProxy
 
readManyAsync(long, int, int, IFunction<E, Boolean>) - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
 
readManyAsync(long, int, int, IFunction<E, Boolean>) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Reads a batch of items from the Ringbuffer.
ReadManyOperation<O> - Class in com.hazelcast.ringbuffer.impl.operations
 
ReadManyOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
 
ReadManyOperation(String, long, int, int, IFunction<O, Boolean>) - Constructor for class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
 
readMap(ObjectDataInput) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
 
readMetadataGroupId() - Method in interface com.hazelcast.cp.internal.persistence.CPMetadataStore
Reads group id of the METADATA group, or reads null if METADATA group id has not changed
readMetadataGroupId() - Method in class com.hazelcast.cp.internal.persistence.NopCPMetadataStore
 
readMetrics(long) - Method in class com.hazelcast.internal.metrics.impl.MetricsService
Read metrics from the journal from the given sequence.
readMetricsAsync(Member, long) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
Reads the metrics journal for a given number starting from a specific sequence.
ReadMetricsMessageTask - Class in com.hazelcast.client.impl.protocol.task.metrics
 
ReadMetricsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.metrics.ReadMetricsMessageTask
 
ReadMetricsOperation - Class in com.hazelcast.internal.metrics.managementcenter
 
ReadMetricsOperation() - Constructor for class com.hazelcast.internal.metrics.managementcenter.ReadMetricsOperation
 
ReadMetricsOperation(long) - Constructor for class com.hazelcast.internal.metrics.managementcenter.ReadMetricsOperation
 
readNullableCollection(ObjectDataInput) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
Reads a collection from the given ObjectDataInput.
readNullableList(ObjectDataInput) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
Reads a list from the given ObjectDataInput.
readNullableMap(ObjectDataInput) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
readNullablePartitionIdSet(ObjectDataInput) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
 
readObject(ObjectDataInput) - Static method in class com.hazelcast.internal.nio.IOUtil
 
readObject(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
readObject(ObjectDataInput, Class) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
readObject() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readObject(Class) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readObject(ObjectDataInput) - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
 
readObject(ObjectDataInput, Class) - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
 
readObject() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readObject(Class) - Method in interface com.hazelcast.nio.ObjectDataInput
 
readOne(long) - Method in class com.hazelcast.client.impl.proxy.ClientRingbufferProxy
 
readOne(long) - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
 
readOne(long) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Reads one item from the Ringbuffer.
ReadOneOperation - Class in com.hazelcast.ringbuffer.impl.operations
 
ReadOneOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
 
ReadOneOperation(String, long) - Constructor for class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
 
ReadOnly - Interface in com.hazelcast.core
Allows notifying Hazelcast that the processing unit implementing this interface will not do any modifications.
ReadonlyKeyBasedMapOperation - Class in com.hazelcast.map.impl.operation
Abstract MapOperation that serves as based for readonly operations.
ReadonlyKeyBasedMapOperation() - Constructor for class com.hazelcast.map.impl.operation.ReadonlyKeyBasedMapOperation
 
ReadonlyKeyBasedMapOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.ReadonlyKeyBasedMapOperation
 
ReadonlyOperation - Interface in com.hazelcast.spi.impl.operationservice
Read-only operations are allowed to run during migration and passive state.
ReadOnlyRecordIterator(Collection<Record>, long, boolean) - Constructor for class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore.ReadOnlyRecordIterator
 
ReadOnlyRecordIterator(Collection<Record>) - Constructor for class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore.ReadOnlyRecordIterator
 
ReadOnlyRingbufferIterator<E> - Class in com.hazelcast.ringbuffer.impl
Read-only iterator over items in a provided Ringbuffer.
readPortable(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readPortable(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readPortable(PortableReader) - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
 
readPortable(PortableReader) - Method in interface com.hazelcast.nio.serialization.Portable
Read portable fields using PortableReader
readPortable(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readPortable(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
 
readPortable(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeys
 
readPortable(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
 
readPortable(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapValueCollection
 
readPortable(PortableReader) - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
 
readPortable(PortableReader) - Method in class com.hazelcast.security.SimpleTokenCredentials
 
readPortable(PortableReader) - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
readPortable(PortableReader) - Method in class com.hazelcast.spi.impl.PortableCachePartitionLostEvent
 
readPortable(PortableReader) - Method in class com.hazelcast.spi.impl.PortableCollection
 
readPortable(PortableReader) - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
 
readPortable(PortableReader) - Method in class com.hazelcast.spi.impl.PortableEntryEvent
 
readPortable(PortableReader) - Method in class com.hazelcast.spi.impl.PortableItemEvent
 
readPortable(PortableReader) - Method in class com.hazelcast.spi.impl.PortableMapPartitionLostEvent
 
readPortable(PortableReader) - Method in class com.hazelcast.spi.impl.PortablePartitionLostEvent
 
readPortableArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readPortableArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readPortableArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readPortableInternal(PortableReader) - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
ReadResultSet<E> - Interface in com.hazelcast.ringbuffer
ReadResultSetImpl<O,E> - Class in com.hazelcast.ringbuffer.impl
A list for the ReadManyOperation.
ReadResultSetImpl() - Constructor for class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
 
ReadResultSetImpl(int, int, SerializationService, IFunction<O, Boolean>) - Constructor for class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
 
ReadResultSetImpl(int, int, SerializationService, Predicate<? super O>, Projection<? super O, E>) - Constructor for class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
 
readShort(ByteAccessStrategy<R>, R, long, boolean) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readShort(byte[], int, boolean) - Static method in class com.hazelcast.internal.nio.Bits
 
readShort(int) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
readShort(ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
readShort(int, ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
readShort(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readShort(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readShort() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readShort(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readShortArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readShortArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readShortArray() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readShortArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readShortArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readShortB(ByteAccessStrategy<R>, R, long) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readShortB(byte[], int) - Static method in class com.hazelcast.internal.nio.Bits
 
readShortL(ByteAccessStrategy<R>, R, long) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readShortL(byte[], int) - Static method in class com.hazelcast.internal.nio.Bits
 
readShortL(ByteBuffer, int) - Static method in class com.hazelcast.internal.nio.Bits
 
readTenant(ObjectDataInput) - Method in class com.hazelcast.cache.impl.PreJoinCacheConfig
 
readTenant(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
 
readThrough - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
true to enable read through from a CacheLoader
readThroughCache(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
readThroughRecord(Data, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
readUnsignedByte() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readUnsignedShort() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readUTF(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readUTF(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readUTF() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readUTF(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readUtf8Char(DataInput, byte) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readUtf8Char(byte[], int, char[], int) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
readUtf8Char(byte[], int, char[], int) - Static method in class com.hazelcast.internal.nio.Bits
 
readUtf8Char(DataInput, byte) - Static method in class com.hazelcast.internal.nio.Bits
 
readUTFArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
readUTFArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
 
readUTFArray() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
readUTFArray() - Method in interface com.hazelcast.nio.ObjectDataInput
 
readUTFArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readUUID(DataInput) - Static method in class com.hazelcast.internal.util.UUIDSerializationUtil
 
readValue(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongSnapshot
 
readValue(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefSnapshot
 
readValue(ObjectDataInput) - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueSnapshot
 
reallocate(long, long, long) - Method in interface com.hazelcast.internal.memory.MemoryAllocator
Accepts the base address and size of a previously allocated block and "reallocates" it by either: Resizing the existing block, if possible.
RealmConfig - Class in com.hazelcast.config.security
Security realm represents the security configuration for part of the system (e.g.
RealmConfig() - Constructor for class com.hazelcast.config.security.RealmConfig
 
rebalanceGroupLeaderships() - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
receive() - Method in class com.hazelcast.spi.discovery.multicast.impl.MulticastDiscoveryReceiver
 
RecentlyActiveSplitBrainProtectionConfigBuilder - Class in com.hazelcast.config
Builder for a SplitBrainProtectionConfig configured with RecentlyActiveSplitBrainProtectionFunction that considers members present in the context of a split brain protection if the last received heartbeat is within a recent window of time.
RecentlyActiveSplitBrainProtectionFunction - Class in com.hazelcast.splitbrainprotection.impl
A split brain protection function that keeps track of the last heartbeat timestamp per member.
RecentlyActiveSplitBrainProtectionFunction(int, int) - Constructor for class com.hazelcast.splitbrainprotection.impl.RecentlyActiveSplitBrainProtectionFunction
 
recomputeWithBaseTime(int) - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
RECONCILIATION_INTERVAL_SECONDS - Static variable in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingTask
 
record - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
Record<V> - Interface in com.hazelcast.map.impl.record
 
RECORD_INFO - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
RECORD_MIGRATION_INFO - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
RECORD_REPLICATION_INFO - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
RecordFactory<T> - Interface in com.hazelcast.map.impl.record
Factory for creating records.
recordFactoryConstructor - Variable in class com.hazelcast.map.impl.MapContainer
 
recordIndexDefinition(IndexConfig) - Method in class com.hazelcast.query.impl.Indexes
Records the given index definition in this indexes without creating an index.
recordInfo - Variable in class com.hazelcast.map.impl.operation.PutBackupOperation
 
RecordInfo - Class in com.hazelcast.map.impl.record
Record info.
RecordInfo() - Constructor for class com.hazelcast.map.impl.record.RecordInfo
 
RecordInfo(RecordInfo) - Constructor for class com.hazelcast.map.impl.record.RecordInfo
 
recordIterator() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
recordIterator() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
recordLoaded - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
RecordMigrationInfo - Class in com.hazelcast.replicatedmap.impl.record
 
RecordMigrationInfo() - Constructor for class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
RecordMigrationInfo(Data, Data, long) - Constructor for class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
RecordReplicationInfo - Class in com.hazelcast.map.impl.record
 
RecordReplicationInfo(Data, Data, RecordInfo) - Constructor for class com.hazelcast.map.impl.record.RecordReplicationInfo
 
RecordReplicationInfo() - Constructor for class com.hazelcast.map.impl.record.RecordReplicationInfo
 
records - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
records - Variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
Records - Class in com.hazelcast.map.impl.record
Contains various factory & helper methods for a Record object.
recordState - Variable in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
recordStore - Variable in class com.hazelcast.cache.impl.operation.CacheOperation
 
recordStore - Variable in class com.hazelcast.map.impl.operation.MapOperation
 
RecordStore<R extends Record> - Interface in com.hazelcast.map.impl.recordstore
Defines a record-store.
RecordStoreAdapter - Class in com.hazelcast.map.impl.recordstore
Record store adapter.
RecordStoreAdapter(RecordStore) - Constructor for class com.hazelcast.map.impl.recordstore.RecordStoreAdapter
 
recordStoreIterator() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
 
recordStoreLoader - Variable in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
RecordStoreMutationObserver<R extends Record> - Interface in com.hazelcast.map.impl.recordstore
Interface for observing RecordStore mutations
recordStores - Variable in class com.hazelcast.cache.impl.CachePartitionSegment
 
recordToData(R) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
recordToData(CacheRecord) - Method in class com.hazelcast.cache.impl.CacheRecordStore
 
recordToValue(R) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
recordToValue(CacheRecord) - Method in class com.hazelcast.cache.impl.CacheRecordStore
 
recordToValue(R) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
recordValue(long) - Method in interface com.hazelcast.internal.diagnostics.StoreLatencyPlugin.LatencyProbe
 
recover(int) - Method in class com.hazelcast.client.impl.proxy.txn.xa.XAResourceProxy
 
recover(int) - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
 
recreate() - Method in interface com.hazelcast.map.impl.querycache.subscriber.InternalQueryCache
Recreates this query cache.
recreate() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
recreateAllCaches() - Method in class com.hazelcast.client.impl.querycache.ClientQueryCacheContext
 
recreateCachesOnCluster() - Method in class com.hazelcast.client.cache.impl.ClientCacheProxyFactory
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.AbstractAllPartitionsMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMultiPartitionMessageTask
 
reduce(Map<Member, Object>) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMultiTargetMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAllMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSizeMessageTask
 
reduce(Map<Member, Object>) - Method in class com.hazelcast.client.impl.protocol.task.CreateProxiesMessageTask
 
reduce(Map<Member, Object>) - Method in class com.hazelcast.client.impl.protocol.task.DeployClassesMessageTask
 
reduce(Collection<AccumulatedResults>) - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
 
reduce(Collection<AggregationResult>) - Method in class com.hazelcast.client.impl.protocol.task.map.DefaultMapAggregateMessageTask
 
reduce(Collection<QueryResult>) - Method in class com.hazelcast.client.impl.protocol.task.map.DefaultMapProjectMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddIndexMessageTask
 
reduce(Map<Member, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddInterceptorMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsValueMessageTask
 
reduce(Collection<QueryResultRow>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPagingPredicateMessageTask
 
reduce(Collection<QueryResultRow>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPredicateMessageTask
 
reduce(Collection<QueryResultRow>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntrySetMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictAllMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnAllKeysMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeysMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteWithPredicateMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
 
reduce(Collection<QueryResultRow>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
 
reduce(Collection<QueryResultRow>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
 
reduce(Collection<QueryResultRow>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapMadePublishableMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveAllMessageTask
 
reduce(Map<Member, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSizeMessageTask
 
reduce(Collection<QueryResultRow>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesMessageTask
 
reduce(Collection<QueryResultRow>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPagingPredicateMessageTask
 
reduce(Collection<QueryResultRow>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPredicateMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapClearMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsValueMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
 
reduce(Map<Member, Object>) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XACollectTransactionsMessageTask
 
reduce(int) - Method in class com.hazelcast.internal.jmx.SemaphoreMBean
 
REDUCE_EVERYTHING - Static variable in class com.hazelcast.query.impl.getters.AbstractMultiValueGetter
 
reduceCollectionInto(MultiResult<Object>, Collection) - Method in class com.hazelcast.query.impl.getters.AbstractMultiValueGetter
 
reduceInto(MultiResult<Object>, Object) - Method in class com.hazelcast.query.impl.getters.AbstractMultiValueGetter
 
reducePermits(int) - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionAwareSemaphoreProxy
 
reducePermits(int) - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionlessSemaphoreProxy
 
reducePermits(int) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionAwareSemaphoreProxy
 
reducePermits(int) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionlessSemaphoreProxy
 
reducePermits(int) - Method in interface com.hazelcast.cp.ISemaphore
Reduces the number of available permits by the indicated amount.
REDUCER_ANY_TOKEN - Static variable in class com.hazelcast.query.impl.getters.AbstractMultiValueGetter
 
REFERENCE_COST_IN_BYTES - Static variable in class com.hazelcast.internal.util.JVMUtil
Defines the costs for a reference in Bytes.
REFERENCE_SIZE - Static variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
If Unsafe is available, Object array index scale (every index represents a reference) can be assumed as reference size.
referenceId - Variable in class com.hazelcast.client.impl.protocol.codec.MapForceUnlockCodec.RequestParameters
The client-wide unique id for this request.
referenceId - Variable in class com.hazelcast.client.impl.protocol.codec.MapLockCodec.RequestParameters
The client-wide unique id for this request.
referenceId - Variable in class com.hazelcast.client.impl.protocol.codec.MapTryLockCodec.RequestParameters
The client-wide unique id for this request.
referenceId - Variable in class com.hazelcast.client.impl.protocol.codec.MapUnlockCodec.RequestParameters
The client-wide unique id for this request.
referenceId - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapForceUnlockCodec.RequestParameters
The client-wide unique id for this request.
referenceId - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapLockCodec.RequestParameters
The client-wide unique id for this request.
referenceId - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapTryLockCodec.RequestParameters
The client-wide unique id for this request.
referenceId - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapUnlockCodec.RequestParameters
The client-wide unique id for this request.
ReflectionHelper - Class in com.hazelcast.query.impl.getters
Scans your classpath, indexes the metadata, allows you to query it on runtime.
refreshClientPermissions(Set<PermissionConfig>) - Method in interface com.hazelcast.security.SecurityService
Propagates changes made to client permissions to all members and reinitiates IPermissionPolicy with new configuration.
refreshPermissions(Set<PermissionConfig>) - Method in interface com.hazelcast.security.IPermissionPolicy
Replaces existing permissions with given set of permissions.
refreshPermissions(Set<PermissionConfig>) - Method in interface com.hazelcast.security.SecurityContext
 
regenerateUuid(int) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataGenerator
 
regex(String, String) - Static method in class com.hazelcast.query.Predicates
Creates a regex predicate that will pass items if the given pattern matches the value stored under the given item attribute.
REGEX_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
RegexConfigPatternMatcher - Class in com.hazelcast.config.matcher
This ConfigPatternMatcher uses Java regular expressions for matching.
RegexConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.RegexConfigPatternMatcher
 
RegexConfigPatternMatcher(int) - Constructor for class com.hazelcast.config.matcher.RegexConfigPatternMatcher
 
RegexPredicate - Class in com.hazelcast.query.impl.predicates
Regex Predicate
RegexPredicate() - Constructor for class com.hazelcast.query.impl.predicates.RegexPredicate
 
RegexPredicate(String, String) - Constructor for class com.hazelcast.query.impl.predicates.RegexPredicate
 
RegionFactoryBeanDefinitionParser - Class in com.hazelcast.spring.hibernate
Parser for RegionFactory.
RegionFactoryBeanDefinitionParser() - Constructor for class com.hazelcast.spring.hibernate.RegionFactoryBeanDefinitionParser
 
register(int, Class, ClientExceptionFactory.ExceptionFactory) - Method in class com.hazelcast.client.impl.clientside.ClientExceptionFactory
 
register(int, Class) - Method in class com.hazelcast.client.impl.protocol.ClientExceptions
 
register(String, ClientProxyFactory) - Method in class com.hazelcast.client.impl.spi.ProxyManager
 
register(String, Class<? extends ClientProxy>) - Method in class com.hazelcast.client.impl.spi.ProxyManager
 
register(TextCommandConstants.TextCommandType, TextCommandProcessor) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
register(DiagnosticsPlugin) - Method in class com.hazelcast.internal.diagnostics.Diagnostics
Registers a DiagnosticsPlugin.
register(HazelcastMBean) - Static method in class com.hazelcast.internal.jmx.HazelcastMBean
 
register(Operation) - Method in class com.hazelcast.internal.metrics.impl.LiveOperationRegistry
 
register(MetricsRegistry) - Static method in class com.hazelcast.internal.metrics.metricsets.ClassLoadingMetricSet
Registers all the metrics in this metric pack.
register(MetricsRegistry) - Static method in class com.hazelcast.internal.metrics.metricsets.FileMetricSet
Registers all the metrics in this metric pack.
register(MetricsRegistry) - Static method in class com.hazelcast.internal.metrics.metricsets.GarbageCollectionMetricSet
Registers all the metrics in this metrics pack.
register(MetricsRegistry) - Static method in class com.hazelcast.internal.metrics.metricsets.OperatingSystemMetricSet
Registers all the metrics in this metrics pack.
register(MetricsRegistry) - Static method in class com.hazelcast.internal.metrics.metricsets.RuntimeMetricSet
Registers all the metrics in this metrics pack.
register(ServiceManager, MetricsRegistry) - Static method in class com.hazelcast.internal.metrics.metricsets.StatisticsAwareMetricsSet
 
register(MetricsRegistry) - Static method in class com.hazelcast.internal.metrics.metricsets.ThreadMetricSet
Registers all the metrics in this metric pack.
register(EndpointQualifier, ChannelInitializerProvider, SocketChannel, boolean) - Method in interface com.hazelcast.internal.networking.Networking
Registers the SocketChannel to the EventLoop group and returns the created Channel.
register(EndpointQualifier, ChannelInitializerProvider, SocketChannel, boolean) - Method in class com.hazelcast.internal.networking.nio.NioNetworking
 
register(Class, Serializer) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
register(String, MapInterceptor) - Method in class com.hazelcast.map.impl.InterceptorRegistry
Registers a MapInterceptor for the supplied `id`.
register(InternalIndex) - Method in class com.hazelcast.query.impl.AttributeIndexRegistry
Registers the given index in this registry.
register(String, int, int, ExecutorType) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
register(String, int, int, ThreadFactory) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
This register method creates the executor only on @ExecutorType.CONCRETE type.
register(String, int, int, ExecutorType) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
register(String, int, int, ThreadFactory) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
register(Invocation) - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
Registers an invocation.
registerAndGetHandler(String, NearCache<K, V>) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingTask
 
registerCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.cache.impl.CacheProxy
 
registerCacheEntryListener(CacheEntryListenerConfiguration<K, V>, boolean) - Method in class com.hazelcast.cache.impl.CacheProxy
 
registerCacheEntryListener(CacheEntryListenerConfiguration<K, V>, boolean) - Method in interface com.hazelcast.cache.impl.ICacheInternal
Registers the provided listener configuration.
registerCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
registerCacheEntryListener(CacheEntryListenerConfiguration<K, V>, boolean) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
registerCacheObject(Object, String, String, boolean) - Static method in class com.hazelcast.cache.impl.MXBeanUtil
Registers the provided CacheMXBean or CacheStatisticsMXBean implementations if not registered yet.
registerClassDefinition(ClassDefinition, Map<Integer, ClassDefinition>, boolean) - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1
 
registerClassDefinition(ClassDefinition) - Method in interface com.hazelcast.internal.serialization.PortableContext
 
registerClassDefinitions(Collection<ClassDefinition>, boolean) - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1
 
registerClient(HazelcastInstance) - Static method in class com.hazelcast.instance.impl.OutOfMemoryErrorDispatcher
 
registerCompletionLatch(int) - Method in class com.hazelcast.cache.impl.AbstractCacheSyncListenerCompleter
 
registerCompletionLatch(Integer, int) - Method in class com.hazelcast.cache.impl.AbstractCacheSyncListenerCompleter
 
registerConfigLocally(IdentifiedDataSerializable, ConfigCheckMode) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
Register a dynamic configuration in a local member.
registerConnection(Address, T) - Method in interface com.hazelcast.internal.nio.EndpointManager
Registers (ie.
registerConnection(Address, TcpIpConnection) - Method in class com.hazelcast.internal.nio.tcp.ClientViewUnifiedEndpointManager
 
registerConnection(Address, TcpIpConnection) - Method in class com.hazelcast.internal.nio.tcp.MemberViewUnifiedEndpointManager
 
registerConnection(Address, TcpIpConnection) - Method in class com.hazelcast.internal.nio.tcp.TcpIpEndpointManager
 
registerConnection(Address, TcpIpConnection) - Method in class com.hazelcast.internal.nio.tcp.TextViewUnifiedEndpointManager
 
registerConstant(Class, Serializer) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
registerConstant(Class, SerializerAdapter) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
registerDynamicMetricsProvider(DynamicMetricsProvider) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
 
registerDynamicMetricsProvider(DynamicMetricsProvider) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
Registers dynamic metrics sources that collect metrics in each metrics collection cycle.
registerEndpoint(ClientEndpoint) - Method in interface com.hazelcast.client.impl.ClientEndpointManager
Registers an endpoint with this ClientEndpointManager.
registerEndpoint(ClientEndpoint) - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
 
registerEngineExtension(String, ScriptEngineFactory) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
 
registerEngineMimeType(String, ScriptEngineFactory) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
 
registerEngineName(String, ScriptEngineFactory) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
 
registerFuture(long, InternalCompletableFuture) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Registers the future for the appended entry with its entryIndex.
registerGlobal(Serializer) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
registerGlobal(Serializer, boolean) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
registerListener(String, CacheEventListener, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
registerListener(String, CacheEventListener, EventFilter, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
registerListener(String, CacheEventListener, boolean) - Method in interface com.hazelcast.cache.impl.ICacheService
 
registerListener(String, CacheEventListener, EventFilter, boolean) - Method in interface com.hazelcast.cache.impl.ICacheService
 
registerListener(ListenerMessageCodec, EventHandler) - Method in interface com.hazelcast.client.impl.spi.ClientListenerService
 
registerListener(ListenerMessageCodec, EventHandler) - Method in class com.hazelcast.client.impl.spi.ClientProxy
 
registerListener(ListenerMessageCodec, EventHandler) - Method in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
registerListener(ListenerMessageCodec, EventHandler) - Method in class com.hazelcast.client.impl.spi.impl.listener.SmartClientListenerService
 
registerListener(Object) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
registerListener(Object) - Method in interface com.hazelcast.instance.impl.NodeExtension
Registers given listener if it's a known type.
registerListener(String, String, Object) - Method in interface com.hazelcast.spi.impl.eventservice.EventService
Registers a listener on all cluster nodes.
registerListener(String, String, EventFilter, Object) - Method in interface com.hazelcast.spi.impl.eventservice.EventService
Registers a listener on all cluster nodes with an event filter.
registerListener(String, String, Object) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
registerListener(String, String, EventFilter, Object) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
registerListenerInternal(String, CacheEventListener, EventFilter, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
registerLocalListener(String, String, Object) - Method in interface com.hazelcast.spi.impl.eventservice.EventService
Registers a local only listener.
registerLocalListener(String, String, EventFilter, Object) - Method in interface com.hazelcast.spi.impl.eventservice.EventService
Registers a local only listener with an event filter.
registerLocalListener(String, String, Object) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
registerLocalListener(String, String, EventFilter, Object) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
registerLockStoreConstructor(String, ConstructorFunction<ObjectNamespace, LockStoreInfo>) - Method in interface com.hazelcast.internal.locksupport.LockSupportService
 
registerLockStoreConstructor(String, ConstructorFunction<ObjectNamespace, LockStoreInfo>) - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
registerPartitionListener(ClientEndpoint, long) - Method in class com.hazelcast.client.impl.ClientPartitionListenerService
 
registerPlugins(Diagnostics) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
registerPlugins(Diagnostics) - Method in interface com.hazelcast.instance.impl.NodeExtension
Register the node extension specific diagnostics plugins on the provided diagnostics.
registerProcessor(Class<? extends Result>, ResultProcessor) - Method in class com.hazelcast.map.impl.query.ResultProcessorRegistry
 
registerPublisher(Function<NodeEngine, MetricsPublisher>) - Method in class com.hazelcast.internal.metrics.impl.MetricsService
Register a custom MetricsPublisher implementation with a register function that takes NodeEngine as input letting the caller to optionally initialize the publisher returned from the function.
registerServer(HazelcastInstance) - Static method in class com.hazelcast.instance.impl.OutOfMemoryErrorDispatcher
 
registerService(String, Object) - Method in class com.hazelcast.spi.impl.servicemanager.impl.ServiceManagerImpl
 
registerStaticMetrics(S, String) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
 
registerStaticMetrics(S) - Method in class com.hazelcast.internal.metrics.impl.MetricTaggerImpl
 
registerStaticMetrics(S, String) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
Scans the source object for any fields/methods that have been annotated with Probe annotation, and registers these fields/methods as static probe instances.
registerStaticMetrics(S) - Method in interface com.hazelcast.internal.metrics.MetricTagger
Scans the source object for any fields/methods that have been annotated with Probe annotation, and registers these fields/methods as probe instances.
registerStaticProbe(S, String, ProbeLevel, LongProbeFunction<S>) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
 
registerStaticProbe(S, String, ProbeLevel, DoubleProbeFunction<S>) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
 
registerStaticProbe(S, String, ProbeLevel, ProbeUnit, DoubleProbeFunction<S>) - Method in class com.hazelcast.internal.metrics.impl.MetricTaggerImpl
 
registerStaticProbe(S, String, ProbeLevel, DoubleProbeFunction<S>) - Method in class com.hazelcast.internal.metrics.impl.MetricTaggerImpl
 
registerStaticProbe(S, String, ProbeLevel, ProbeUnit, LongProbeFunction<S>) - Method in class com.hazelcast.internal.metrics.impl.MetricTaggerImpl
 
registerStaticProbe(S, String, ProbeLevel, LongProbeFunction<S>) - Method in class com.hazelcast.internal.metrics.impl.MetricTaggerImpl
 
registerStaticProbe(S, String, ProbeLevel, LongProbeFunction<S>) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
Registers a probe.
registerStaticProbe(S, String, ProbeLevel, DoubleProbeFunction<S>) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
Registers a probe.
registerStaticProbe(S, String, ProbeLevel, ProbeUnit, DoubleProbeFunction<S>) - Method in interface com.hazelcast.internal.metrics.MetricTagger
Registers a single probe.
registerStaticProbe(S, String, ProbeLevel, DoubleProbeFunction<S>) - Method in interface com.hazelcast.internal.metrics.MetricTagger
Registers a single probe.
registerStaticProbe(S, String, ProbeLevel, ProbeUnit, LongProbeFunction<S>) - Method in interface com.hazelcast.internal.metrics.MetricTagger
Registers a single probe.
registerStaticProbe(S, String, ProbeLevel, LongProbeFunction<S>) - Method in interface com.hazelcast.internal.metrics.MetricTagger
Registers a single probe.
registerUnsafeWaitingOperation(CPGroupId, long, Operation) - Method in class com.hazelcast.cp.internal.RaftService
 
Registration - Class in com.hazelcast.spi.impl.eventservice.impl
 
Registration() - Constructor for class com.hazelcast.spi.impl.eventservice.impl.Registration
 
Registration(UUID, String, String, EventFilter, Address, Object, boolean) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.Registration
 
REGISTRATION - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
REGISTRATION_OPERATION - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
registrationId - Variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveEntryListenerCodec.RequestParameters
The id assigned during the registration for the listener which shall be removed.
registrationId - Variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveInvalidationListenerCodec.RequestParameters
The id assigned during the registration for the listener which shall be removed.
registrationId - Variable in class com.hazelcast.client.impl.protocol.codec.CacheRemovePartitionLostListenerCodec.RequestParameters
ID of registered listener.
registrationId - Variable in class com.hazelcast.client.impl.protocol.codec.ClientRemoveDistributedObjectListenerCodec.RequestParameters
The id assigned during the registration.
registrationId - Variable in class com.hazelcast.client.impl.protocol.codec.ClientRemovePartitionLostListenerCodec.RequestParameters
The id assigned during the listener registration.
registrationId - Variable in class com.hazelcast.client.impl.protocol.codec.ListRemoveListenerCodec.RequestParameters
The id of the listener which was provided during registration.
registrationId - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveEntryListenerCodec.RequestParameters
id of registered listener.
registrationId - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemovePartitionLostListenerCodec.RequestParameters
id of register
registrationId - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryListenerCodec.RequestParameters
Registration id of listener
registrationId - Variable in class com.hazelcast.client.impl.protocol.codec.QueueRemoveListenerCodec.RequestParameters
Id of the listener registration.
registrationId - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveEntryListenerCodec.RequestParameters
ID of the registered entry listener.
registrationId - Variable in class com.hazelcast.client.impl.protocol.codec.SetRemoveListenerCodec.RequestParameters
The id retrieved during registration.
registrationId - Variable in class com.hazelcast.client.impl.protocol.codec.TopicRemoveMessageListenerCodec.RequestParameters
Id of listener registration.
RegistrationOperation - Class in com.hazelcast.spi.impl.eventservice.impl.operations
 
RegistrationOperation() - Constructor for class com.hazelcast.spi.impl.eventservice.impl.operations.RegistrationOperation
 
RegistrationOperation(Registration, int) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.operations.RegistrationOperation
 
RegistrationOperationSupplier - Class in com.hazelcast.spi.impl.eventservice.impl.operations
Supplier that creates RegistrationOperations for a listener registration.
RegistrationOperationSupplier(Registration, ClusterService) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.operations.RegistrationOperationSupplier
 
registrations - Variable in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
Registry<K,T> - Interface in com.hazelcast.map.impl.querycache
General contract to define any id --&gt; item registration.
rehash(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
REJECTED_EXECUTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
rejectExecution() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
 
release() - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionAwareSemaphoreProxy
 
release(int) - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionAwareSemaphoreProxy
 
release() - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionlessSemaphoreProxy
 
release(int) - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionlessSemaphoreProxy
 
release(CPGroupId, long, String, LockEndpoint, UUID) - Method in class com.hazelcast.cp.internal.datastructures.lock.LockService
 
release() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionAwareSemaphoreProxy
 
release(int) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionAwareSemaphoreProxy
 
release() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionlessSemaphoreProxy
 
release(int) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionlessSemaphoreProxy
 
release() - Method in interface com.hazelcast.cp.ISemaphore
Releases a permit and increases the number of available permits by one.
release(int) - Method in interface com.hazelcast.cp.ISemaphore
Releases the given number of permits and increases the number of available permits by that amount.
release(int) - Method in class com.hazelcast.internal.jmx.SemaphoreMBean
 
release() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationQueue
 
release() - Method in class com.hazelcast.internal.util.DirectoryLock
Releases the lock on directory.
RELEASE_PERMITS_OP - Static variable in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreDataSerializerHook
 
releaseAllReservations() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.TxnReservedCapacityCounter
Releases all reserved capacity info on this counter.
releaseAllReservations() - Method in class com.hazelcast.map.impl.mapstore.writebehind.TxnReservedCapacityCounterImpl
 
releasePermits(CPGroupId, long, String, SemaphoreEndpoint, UUID, int) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreService
 
ReleasePermitsMessageTask - Class in com.hazelcast.cp.internal.datastructures.semaphore.client
Client message task for ReleasePermitsOp
ReleasePermitsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.client.ReleasePermitsMessageTask
 
ReleasePermitsOp - Class in com.hazelcast.cp.internal.datastructures.semaphore.operation
Operation for ISemaphore.release()
ReleasePermitsOp() - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.operation.ReleasePermitsOp
 
ReleasePermitsOp(String, long, long, UUID, int) - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.operation.ReleasePermitsOp
 
releasePromotionPermit() - Method in class com.hazelcast.internal.partition.impl.MigrationManager
Releases promotion commit permit.
releaseReplicaSyncPermits(int) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
Releases the previously acquired permits.
releaseSession(RaftGroupId, long) - Method in class com.hazelcast.cp.internal.session.AbstractProxySessionManager
Decrements acquire count of the session.
releaseSession(RaftGroupId, long, int) - Method in class com.hazelcast.cp.internal.session.AbstractProxySessionManager
Decrements acquire count of the session.
releaseSession(long) - Method in class com.hazelcast.cp.internal.session.SessionAwareProxy
Decrements acquire count of the session.
releaseSession(long, int) - Method in class com.hazelcast.cp.internal.session.SessionAwareProxy
Decrements acquire count of the session.
RELIABLE_TOPIC_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
RELIABLE_TOPIC_MESSAGE - Static variable in class com.hazelcast.topic.impl.TopicDataSerializerHook
 
ReliableMessageListener<E> - Interface in com.hazelcast.topic
A MessageListener to better integrate with the reliable topic.
ReliableMessageListenerAdapter<E> - Class in com.hazelcast.topic.impl.reliable
 
ReliableMessageListenerAdapter(MessageListener<E>) - Constructor for class com.hazelcast.topic.impl.reliable.ReliableMessageListenerAdapter
 
ReliableMessageRunner<E> - Class in com.hazelcast.topic.impl.reliable
 
ReliableTopicConfig - Class in com.hazelcast.config
Configuration for a reliable ITopic.
ReliableTopicConfig() - Constructor for class com.hazelcast.config.ReliableTopicConfig
 
ReliableTopicConfig(String) - Constructor for class com.hazelcast.config.ReliableTopicConfig
Creates a new ReliableTopicConfig with default settings.
ReliableTopicConfig(ReliableTopicConfig) - Constructor for class com.hazelcast.config.ReliableTopicConfig
Creates a new ReliableTopicConfig by cloning an existing one.
ReliableTopicConfigReadOnly - Class in com.hazelcast.internal.config
 
ReliableTopicConfigReadOnly(ReliableTopicConfig) - Constructor for class com.hazelcast.internal.config.ReliableTopicConfigReadOnly
 
ReliableTopicMBean - Class in com.hazelcast.internal.jmx
Management bean for reliable topic
ReliableTopicMBean(ReliableTopicProxy, ManagementService) - Constructor for class com.hazelcast.internal.jmx.ReliableTopicMBean
 
ReliableTopicMessage - Class in com.hazelcast.topic.impl.reliable
The Object that is going to be stored in the Ringbuffer.
ReliableTopicMessage() - Constructor for class com.hazelcast.topic.impl.reliable.ReliableTopicMessage
 
ReliableTopicMessage(Data, Address) - Constructor for class com.hazelcast.topic.impl.reliable.ReliableTopicMessage
 
ReliableTopicProxy<E> - Class in com.hazelcast.topic.impl.reliable
The serverside ITopic implementation for reliable topics.
ReliableTopicProxy(String, NodeEngine, ReliableTopicService, ReliableTopicConfig) - Constructor for class com.hazelcast.topic.impl.reliable.ReliableTopicProxy
 
ReliableTopicService - Class in com.hazelcast.topic.impl.reliable
 
ReliableTopicService(NodeEngine) - Constructor for class com.hazelcast.topic.impl.reliable.ReliableTopicService
 
reloadManagers() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
This method is the only one that is visible and not part of the ScriptEngineManager class.
reloadOwnedPartitions() - Method in interface com.hazelcast.map.impl.MapServiceContext
Reloads the cached collection of partitions owned by this node.
REMAINING_CAPACITY - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
remainingCapacity() - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
remainingCapacity() - Method in class com.hazelcast.client.impl.proxy.ClientRingbufferProxy
 
remainingCapacity() - Method in class com.hazelcast.internal.util.concurrent.MPSCQueue
 
remainingCapacity() - Method in interface com.hazelcast.internal.util.concurrent.Pipe
Returns the number of items this pipe has still room for.
remainingCapacity() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
Returns the remaining capacity of the ringbuffer.
remainingCapacity() - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
 
remainingCapacity() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Returns the remaining capacity of the ringbuffer.
RemainingCapacityOperation - Class in com.hazelcast.collection.impl.queue.operations
Returns the remaining capacity of the queue based on config max-size
RemainingCapacityOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.RemainingCapacityOperation
 
RemainingCapacityOperation(String) - Constructor for class com.hazelcast.collection.impl.queue.operations.RemainingCapacityOperation
 
remainingQueueCapacity - Variable in class com.hazelcast.internal.management.dto.ManagedExecutorDTO
 
REMOTE_MAP_REDUCE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
RemoteAddressProvider - Class in com.hazelcast.client.impl.spi.impl.discovery
 
RemoteAddressProvider(Callable<Map<Address, Address>>, boolean) - Constructor for class com.hazelcast.client.impl.spi.impl.discovery.RemoteAddressProvider
 
RemoteEventProcessor - Class in com.hazelcast.spi.impl.eventservice.impl
An extension of the EventProcessor which logs and swallows any exception while processing the event.
RemoteEventProcessor(EventServiceImpl, Packet) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.RemoteEventProcessor
 
remoteMembers() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftGroupMembers
Returns remote members in this group, excluding the local member.
remoteMembers() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns remote members in the last applied group members
RemoteMerkleTreeView - Class in com.hazelcast.wan.impl.merkletree
Represents the readonly view of a remote Merkle Tree.
remoteOperationCount - Variable in class com.hazelcast.internal.management.dto.OperationServiceDTO
 
RemoteService - Interface in com.hazelcast.internal.services
An interface that can be implemented by SPI-Services to give them the ability to create proxies to distributed objects.
remoteService - Variable in class com.hazelcast.map.impl.MapService
 
remoteSocketAddress() - Method in class com.hazelcast.internal.networking.AbstractChannel
 
remoteSocketAddress() - Method in interface com.hazelcast.internal.networking.Channel
 
REMOVALS - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
removals - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
remove(Object) - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
remove(Data, UUID, UUID, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
remove(Data, UUID, UUID, int, CallerProvenance) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
remove(Data, Object, UUID, UUID, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
remove() - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
REMOVE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
remove() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
remove(K) - Method in class com.hazelcast.cache.impl.CacheProxy
 
remove(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
 
remove(Data, UUID, UUID, int, CallerProvenance) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Removes the mapping for a key from this cache if it is present.
remove(Data, UUID, UUID, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
 
remove(Data, Object, UUID, UUID, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Atomically removes the mapping for a key only if currently mapped to the given value.
remove(Object) - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap
 
remove(Object, Object) - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap
 
remove(K) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
remove(K, V) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
remove() - Method in class com.hazelcast.client.impl.clientside.ClientDiscoveryService
 
remove(int) - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
remove(Object) - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
remove(Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
remove(Object, Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
remove(Object, Object) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
remove(Object) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
remove(Object) - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
remove() - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
remove(Object) - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
remove(Object) - Method in class com.hazelcast.client.impl.proxy.ClientSetProxy
 
remove(E) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnListProxy
 
remove(Object) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
remove(Object, Object) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
remove(Object, Object) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMultiMapProxy
 
remove(Object) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMultiMapProxy
 
remove(E) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnSetProxy
 
remove(Object) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
remove(Data) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
remove(int) - Method in class com.hazelcast.collection.impl.list.ListContainer
 
remove(int) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
 
remove(Data) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Iterates all items, checks equality with data This method does not trigger store load.
REMOVE - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
remove() - Method in class com.hazelcast.collection.impl.queue.QueueIterator
 
remove(Object) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
remove() - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
remove(E) - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
 
remove(RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.state.LeaderState
Removes a follower from leader maintained state.
remove() - Method in class com.hazelcast.durableexecutor.impl.TaskRingBuffer.DurableIterator
 
remove(int) - Method in class com.hazelcast.durableexecutor.impl.TaskRingBuffer
Removes the task with the given sequence
remove(HazelcastInstanceImpl) - Static method in class com.hazelcast.instance.impl.HazelcastInstanceFactory
 
remove(K) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
remove(K, V) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
remove(K) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
remove(K, V) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
remove(K) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
remove(K, V) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
remove(K) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
remove(K, V) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
remove(K) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
remove(K, V) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
remove(Member) - Method in interface com.hazelcast.internal.cluster.fd.ClusterFailureDetector
Deregister member from tracking and cleanup resources related to this member.
remove(Member) - Method in class com.hazelcast.internal.cluster.fd.DeadlineClusterFailureDetector
 
remove(Member) - Method in class com.hazelcast.internal.cluster.fd.PhiAccrualClusterFailureDetector
 
remove(E) - Method in class com.hazelcast.internal.cluster.fd.PingFailureDetector
 
remove(Object) - Method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
 
remove(Object) - Method in class com.hazelcast.internal.dynamicconfig.AggregatingMap
 
remove(int) - Method in class com.hazelcast.internal.json.JsonArray
Removes the element at the specified index from this array.
remove(String) - Method in class com.hazelcast.internal.json.JsonObject
Removes a member with the specified name from this object.
remove() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationQueue
 
remove(Object) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationQueue
 
remove(InboundHandler) - Method in interface com.hazelcast.internal.networking.InboundPipeline
Removes the given handler from the pipeline.
remove(InboundHandler) - Method in class com.hazelcast.internal.networking.nio.NioInboundPipeline
 
remove(OutboundHandler) - Method in class com.hazelcast.internal.networking.nio.NioOutboundPipeline
 
remove(OutboundHandler) - Method in interface com.hazelcast.internal.networking.OutboundPipeline
Removes the given handler from the pipeline.
remove(T[], T) - Static method in class com.hazelcast.internal.util.collection.ArrayUtils
Removes an item from the array.
remove(int, int) - Method in class com.hazelcast.internal.util.collection.BiInt2ObjectMap
Remove a value from the map and return the value.
remove(Object) - Method in class com.hazelcast.internal.util.collection.ImmutableInflatableSet
 
remove(Object) - Method in class com.hazelcast.internal.util.collection.ImmutablePartitionIdSet
 
remove(int) - Method in class com.hazelcast.internal.util.collection.ImmutablePartitionIdSet
 
remove(Object) - Method in class com.hazelcast.internal.util.collection.InflatableSet
 
remove(Object) - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap.KeySet
 
remove(int) - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap.KeySet
Non-boxing variant of remove().
remove(Object) - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
 
remove(int) - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
Overloaded version of Map.remove(Object) that takes a primitive int key.
remove(Object) - Method in class com.hazelcast.internal.util.collection.IntHashSet
 
remove(int) - Method in class com.hazelcast.internal.util.collection.IntHashSet
An int specialised version of {this#remove(Object)}.
remove() - Method in class com.hazelcast.internal.util.collection.IntIterator
 
remove(Object) - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
 
remove(long) - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
 
remove(long) - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
 
remove(long, long) - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
 
remove(long) - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
 
remove(long, long) - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
 
remove(Object) - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap.KeySet
 
remove(long) - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap.KeySet
Non-boxing variant of remove().
remove(Object) - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
 
remove(long) - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
Overloaded version of Map.remove(Object) that takes a primitive long key.
remove(Object) - Method in class com.hazelcast.internal.util.collection.LongHashSet
remove(long) - Method in class com.hazelcast.internal.util.collection.LongHashSet
An long specialised version of {this#remove(Object)}.
remove() - Method in class com.hazelcast.internal.util.collection.LongIterator
 
remove(long) - Method in interface com.hazelcast.internal.util.collection.LongSet
 
remove(long) - Method in class com.hazelcast.internal.util.collection.LongSetHsa
 
remove(Object) - Method in class com.hazelcast.internal.util.collection.OAHashSet
 
remove(Object, int) - Method in class com.hazelcast.internal.util.collection.OAHashSet
Removes the specified element from this set if it is present with the hash provided in parameter.
remove(Object) - Method in class com.hazelcast.internal.util.collection.PartitionIdSet
 
remove(int) - Method in class com.hazelcast.internal.util.collection.PartitionIdSet
 
remove(Object) - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
Removes the key (and its corresponding value) from this map.
remove(Object, Object) - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
remove(long, int) - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray12byteKey
Removes the mapping for (key1, key2), if any.
remove(long, long) - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray16byteKey
Removes the mapping for (key1, key2), if any.
remove(long) - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray8byteKey
Removes the mapping for the given key.
remove(long, int) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray12byteKeyImpl
 
remove(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyImpl
 
remove(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyNoValue
 
remove(long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray8byteKeyImpl
 
remove(T) - Method in class com.hazelcast.internal.util.ItemCounter
 
remove() - Method in class com.hazelcast.internal.util.iterator.RestartingMemberIterator
 
remove(K) - Method in class com.hazelcast.internal.util.Memoizer
Removes the entry associated with the given key
remove(Object) - Method in class com.hazelcast.internal.util.ResultSet
 
remove() - Method in class com.hazelcast.internal.util.UnmodifiableIterator
 
remove(Object) - Method in interface com.hazelcast.map.BaseMap
Removes the mapping for a key from this map if it is present.
remove(Object, Object) - Method in interface com.hazelcast.map.BaseMap
Removes the entry for a key only if currently mapped to a given value.
remove(Object) - Method in interface com.hazelcast.map.IMap
Removes the mapping for a key from this map if it is present.
remove(Object, Object) - Method in interface com.hazelcast.map.IMap
Removes the entry for a key only if currently mapped to a given value.
remove() - Method in class com.hazelcast.map.impl.iterator.AbstractMapPartitionIterator
 
remove() - Method in class com.hazelcast.map.impl.iterator.AbstractMapQueryPartitionIterator
 
remove() - Method in class com.hazelcast.map.impl.LazyMapEntry
Similar to calling LazyMapEntry.setValue(V) with null but doesn't return old-value hence no extra deserialization.
REMOVE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
remove(K, long, UUID) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
 
remove(Data, long, UUID) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
remove(Data, long, UUID) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
remove(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
remove(Object, Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
remove(Object) - Method in class com.hazelcast.map.impl.query.QueryResultCollection
 
remove(String, String) - Method in interface com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfoSupplier
Removes AccumulatorInfo from this supplier.
remove(String, String) - Method in class com.hazelcast.map.impl.querycache.accumulator.DefaultAccumulatorInfoSupplier
 
remove(String) - Method in class com.hazelcast.map.impl.querycache.publisher.MapListenerRegistry
 
remove(String) - Method in class com.hazelcast.map.impl.querycache.publisher.MapPublisherRegistry
 
remove(Integer) - Method in class com.hazelcast.map.impl.querycache.publisher.PartitionAccumulatorRegistry
 
remove(String) - Method in class com.hazelcast.map.impl.querycache.publisher.PublisherRegistry
 
remove(String) - Method in class com.hazelcast.map.impl.querycache.publisher.QueryCacheListenerRegistry
 
remove(K) - Method in interface com.hazelcast.map.impl.querycache.Registry
Removes the registration from this registry.
remove(String) - Method in class com.hazelcast.map.impl.querycache.subscriber.MapSubscriberRegistry
 
remove(InternalQueryCache) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheFactory
 
remove(Data) - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordStore
 
remove(String) - Method in class com.hazelcast.map.impl.querycache.subscriber.SubscriberRegistry
 
remove() - Method in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore.ReadOnlyRecordIterator
 
remove(Data, CallerProvenance) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
remove(Data, Object) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
remove(Data, CallerProvenance) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
remove(Data, Object) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
remove(Object, Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
remove(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
remove(Object, Object) - Method in interface com.hazelcast.multimap.BaseMultiMap
Removes the given key value pair from the multimap.
remove(Object) - Method in interface com.hazelcast.multimap.BaseMultiMap
Removes all the entries associated with the given key.
remove(Data, boolean) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
REMOVE - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
remove(Object, Object) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
remove(Object) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
remove(Object, Object) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
 
remove(Object) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
 
remove(Object, Object) - Method in interface com.hazelcast.multimap.MultiMap
Removes the given key value pair from the multimap.
remove(Object) - Method in interface com.hazelcast.multimap.MultiMap
Removes all the entries with the given key.
remove(Object, Data, IndexOperationStats) - Method in class com.hazelcast.query.impl.BaseIndexStore
 
remove(Object, Data, IndexOperationStats) - Method in interface com.hazelcast.query.impl.IndexStore
Removes the existing entry mapping in this index.
REMOVE - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
remove(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
remove(K, ReplicatedRecord<K, V>) - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
 
remove(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
remove(Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
remove() - Method in class com.hazelcast.ringbuffer.impl.ReadOnlyRingbufferIterator
 
remove() - Method in class com.hazelcast.spi.impl.merge.AbstractContainerCollector.EmptyIterator
 
remove(Object) - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
 
remove() - Method in class com.hazelcast.spi.merge.RingbufferMergeDataReadOnlyIterator
 
remove(Object) - Method in class com.hazelcast.transaction.impl.SuspendedTransaction
 
remove(Object) - Method in interface com.hazelcast.transaction.impl.Transaction
 
remove(Object) - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
remove(Object) - Method in class com.hazelcast.transaction.impl.TransactionLog
 
remove(Object) - Method in class com.hazelcast.transaction.impl.xa.XATransaction
 
remove(E) - Method in interface com.hazelcast.transaction.TransactionalList
Removes an item from the transactional list.
remove(Object) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.remove(Object).
remove(Object, Object) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.remove(Object, Object).
remove(Object, Object) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
Removes the given key value pair from the multimap.
remove(Object) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
Removes all the entries associated with the given key.
remove(E) - Method in interface com.hazelcast.transaction.TransactionalSet
Remove item from transactional set.
remove0(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
REMOVE_ALL - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
REMOVE_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
REMOVE_ALL_BACKUP - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
REMOVE_ALL_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
REMOVE_ALL_FACTORY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
REMOVE_BACKUP - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
REMOVE_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
REMOVE_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
REMOVE_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
REMOVE_CP_MEMBER_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
REMOVE_FROM_LOAD_ALL - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
REMOVE_IF_SAME - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
REMOVE_INDEX - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
REMOVE_INDEX_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
REMOVE_INTERCEPTOR - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
REMOVE_TIME_TAKEN_NANOS - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
removeAccumulator(PublisherContext, int) - Static method in class com.hazelcast.map.impl.querycache.publisher.AccumulatorSweeper
 
removeAck(RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.state.QueryState
Returns true if the given follower is removed from the ack list.
removeAll(Collection<?>) - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
removeAll(Set<Data>, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
removeAll(Set<? extends K>) - Method in class com.hazelcast.cache.impl.CacheProxy
 
removeAll() - Method in class com.hazelcast.cache.impl.CacheProxy
 
removeAll(Set<Data>, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
records of keys will be deleted one by one and will publish a REMOVE event for each key.
removeAll(Set<? extends K>) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
removeAll() - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
removeAll() - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
removeAll(Collection<?>) - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
removeAll(Predicate<K, V>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
removeAll(Collection<?>) - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
removeAll(Collection<?>) - Method in class com.hazelcast.client.impl.proxy.ClientSetProxy
 
removeAll(Collection<?>) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
removeAll(Collection<?>) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
removeAll() - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
removeAll(Set<K>) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
removeAll() - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
removeAll(Set<K>) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
removeAll() - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
removeAll(Set<K>) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
removeAll() - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
removeAll(Set<K>) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
removeAll() - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
removeAll(Set<K>) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
removeAll(Collection<?>) - Method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
 
removeAll(Collection<?>) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationQueue
 
removeAll(Collection<?>) - Method in class com.hazelcast.internal.util.collection.ImmutableInflatableSet
 
removeAll(PartitionIdSet) - Method in class com.hazelcast.internal.util.collection.ImmutablePartitionIdSet
 
removeAll(Collection<?>) - Method in class com.hazelcast.internal.util.collection.IntHashSet
 
removeAll(Collection<?>) - Method in class com.hazelcast.internal.util.collection.LongHashSet
removeAll(Collection<?>) - Method in class com.hazelcast.internal.util.collection.OAHashSet
 
removeAll(PartitionIdSet) - Method in class com.hazelcast.internal.util.collection.PartitionIdSet
 
removeAll(Collection<?>) - Method in class com.hazelcast.internal.util.ResultSet
 
removeAll(Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
Removes all entries which match with the supplied predicate.
removeAll(Collection) - Method in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
Removes keys from map store.
removeAll(Collection) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
Removes keys from map store.
removeAll(Predicate<K, V>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
removeAll(Collection<?>) - Method in class com.hazelcast.map.impl.query.QueryResultCollection
 
removeAll(Collection<?>) - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
 
RemoveAllBackupOperation - Class in com.hazelcast.multimap.impl.operations
 
RemoveAllBackupOperation() - Constructor for class com.hazelcast.multimap.impl.operations.RemoveAllBackupOperation
 
RemoveAllBackupOperation(String, Data) - Constructor for class com.hazelcast.multimap.impl.operations.RemoveAllBackupOperation
 
removeAllInternal(Predicate) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
removeAllInternal(Predicate) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
removeAllInternal(Predicate) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
removeAllKeysInternal(Set<? extends K>, Collection<Data>, long) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
removeAllListeners(String, String) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheEventService
 
removeAllListeners(String) - Method in class com.hazelcast.client.impl.querycache.subscriber.QueryCacheToListenerMapper
Removes all associated listener info for the cache represented with the supplied cacheId
removeAllListeners(String, String) - Method in interface com.hazelcast.map.impl.querycache.QueryCacheEventService
Removes all user defined listeners associated to supplied cacheId
removeAllListeners(String, String) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheEventService
 
RemoveAllListenersMessageTask - Class in com.hazelcast.client.impl.protocol.task
 
RemoveAllListenersMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
 
RemoveAllOperation - Class in com.hazelcast.multimap.impl.operations
 
RemoveAllOperation() - Constructor for class com.hazelcast.multimap.impl.operations.RemoveAllOperation
 
RemoveAllOperation(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.RemoveAllOperation
 
removeAsync(K) - Method in interface com.hazelcast.cache.ICache
Asynchronously removes the mapping for a key from this cache if it is present.
removeAsync(K, V) - Method in interface com.hazelcast.cache.ICache
Asynchronously removes the mapping for the given key if and only if the currently mapped value equals to the value of oldValue.
removeAsync(K) - Method in class com.hazelcast.cache.impl.CacheProxy
 
removeAsync(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
 
removeAsync(K) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
removeAsync(K, V) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
removeAsync(K) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
removeAsync(K) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
removeAsync(K) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
removeAsync(K) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
removeAsync(K) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
removeAsync(K) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
removeAsync(K) - Method in interface com.hazelcast.map.IMap
Asynchronously removes the given key, returning an CompletionStage on which the caller can register further computation stages to be invoked upon remove operation completion or block waiting for the operation to complete using one of blocking ways to wait on CompletionStage.toCompletableFuture().
removeAsync(K) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
removeAsyncInternal(Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
removeAsyncInternal(Object) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
removeAsyncInternal(Object) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
removeAttribute(String) - Method in class com.hazelcast.client.impl.MemberImpl
 
removeAttribute(String) - Method in class com.hazelcast.cluster.impl.MemberImpl
 
removeAttribute(String) - Method in interface com.hazelcast.cluster.Member
Removes a key-value pair attribute for this member if given key was previously assigned as an attribute.
If key wasn't assigned to a value this method does nothing.
removeAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
removeAttribute(String) - Method in class com.hazelcast.internal.config.MemberAttributeConfigReadOnly
 
removeAttribute(String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
removeAttributeNode(Attr) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
removeAttributeNS(String, String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
removeBackup(long) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
removeBackup(long) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Removes a queue item from the backup map.
removeBackup(K, long, UUID) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
 
removeBackup(Data, long, UUID) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
removeBackup(Data, long, UUID) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
removeBackup(Data, CallerProvenance) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
removeBackup(Data, CallerProvenance) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Similar to RecordStore.remove(Data, CallerProvenance) except removeBackup doesn't touch mapstore since it does not return previous value.
RemoveBackupOperation - Class in com.hazelcast.collection.impl.queue.operations
Remove backup of the Queue item.
RemoveBackupOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.RemoveBackupOperation
 
RemoveBackupOperation(String, long) - Constructor for class com.hazelcast.collection.impl.queue.operations.RemoveBackupOperation
 
RemoveBackupOperation - Class in com.hazelcast.map.impl.operation
 
RemoveBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.RemoveBackupOperation
 
RemoveBackupOperation(String, Data, boolean) - Constructor for class com.hazelcast.map.impl.operation.RemoveBackupOperation
 
RemoveBackupOperation - Class in com.hazelcast.multimap.impl.operations
 
RemoveBackupOperation() - Constructor for class com.hazelcast.multimap.impl.operations.RemoveBackupOperation
 
RemoveBackupOperation(String, Data, Data) - Constructor for class com.hazelcast.multimap.impl.operations.RemoveBackupOperation
 
removeBackupTxn(Data, CallerProvenance, UUID) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
removeBackupTxn(Data, CallerProvenance, UUID) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
removeCache(String, boolean) - Method in interface com.hazelcast.cache.HazelcastCacheManager
Removes the associated cache with the given cache name.
removeCache(String, boolean) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
removeCacheConfigFromLocal(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
Removes the local copy of the cache configuration if one exists.
removeCacheConfigFromLocal(String) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
 
removeCacheConfigFromLocal(String) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
 
removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.config.AbstractCacheConfig
Remove a configuration for a CacheEntryListener.
removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in interface com.hazelcast.config.CacheConfiguration
Remove a configuration for a CacheEntryListener.
removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
removeChild(Node) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
removeChild(String) - Method in interface com.hazelcast.internal.yaml.MutableYamlMapping
Removes a child with the given name if exists
removeChild(String) - Method in class com.hazelcast.internal.yaml.YamlMappingImpl
 
removeClientListener(UUID) - Method in interface com.hazelcast.client.ClientService
Removes a ClientListener.
removeClientListener(UUID) - Method in class com.hazelcast.client.impl.ClientServiceProxy
 
removeConfiguration(String, String) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheConfigurator
 
removeConfiguration(String, String) - Method in interface com.hazelcast.map.impl.querycache.QueryCacheConfigurator
Removes corresponding configuration for the supplied cacheName
removeConfiguration(String, String) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheConfigurator
 
removeContainer(String) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorPartitionContainer
 
removeCounter(String) - Method in class com.hazelcast.wan.DistributedServiceWanEventCounters
Removes the counter for the given dataStructureName.
removeCounter(String, String) - Method in class com.hazelcast.wan.impl.WanEventCounters
Removes the counter for the given serviceName and dataStructureName.
removeCPMember(UUID) - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Removes the given unreachable CP member from the active CP members list and all CP groups it belongs to.
removeCPMember(UUID) - Method in class com.hazelcast.cp.internal.RaftService
 
RemoveCPMemberOp - Class in com.hazelcast.cp.internal.raftop.metadata
When a CP member is shutting down gracefully, or a crashed CP member is removed from CP Subsystem via RaftService#removeCPMember(String), this operation is committed to the Metadata Raft group.
RemoveCPMemberOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.RemoveCPMemberOp
 
RemoveCPMemberOp(CPMemberInfo) - Constructor for class com.hazelcast.cp.internal.raftop.metadata.RemoveCPMemberOp
 
removedCount() - Method in interface com.hazelcast.internal.util.concurrent.Pipe
Returns the number of items removed from this pipe since creation.
removeDestroyAction(UUID) - Method in interface com.hazelcast.client.impl.ClientEndpoint
 
removeDestroyAction(UUID) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
removeDistributedObjectListener(UUID) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
removeDistributedObjectListener(UUID) - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
removeDistributedObjectListener(UUID) - Method in class com.hazelcast.client.impl.spi.ProxyManager
 
removeDistributedObjectListener(UUID) - Method in interface com.hazelcast.core.HazelcastInstance
Removes the specified Distributed Object listener.
removeDistributedObjectListener(UUID) - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
removeDistributedObjectListener(UUID) - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
RemoveDistributedObjectListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task
 
RemoveDistributedObjectListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
 
removeEndpoint(ClientEndpoint) - Method in interface com.hazelcast.client.impl.ClientEndpointManager
Removes an endpoint from this ClientEndpointManager.
removeEndpoint(ClientEndpoint) - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
 
removeEndpoint(Address) - Method in interface com.hazelcast.internal.nio.IOService
 
removeEndpoint(Address) - Method in class com.hazelcast.internal.nio.NodeIOService
 
removeEntriesOf(int) - Method in interface com.hazelcast.map.impl.querycache.subscriber.InternalQueryCache
Scans all entries in this QueryCache to remove matching ones with supplied partitionId
removeEntriesOf(int) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
removeEntry(Data, Object, Index.OperationSource) - Method in class com.hazelcast.query.impl.AbstractIndex
 
removeEntry(Data, Object, Index.OperationSource) - Method in interface com.hazelcast.query.impl.Index
Removes the entry having the given key and the value from this index.
removeEntry(Data, Object, Index.OperationSource) - Method in class com.hazelcast.query.impl.Indexes
Removes the entry from this indexes instance identified by the given key and value.
removeEntryListener(UUID) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
removeEntryListener(UUID) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
removeEntryListener(UUID) - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
removeEntryListener(UUID) - Method in interface com.hazelcast.map.IMap
Removes the specified entry listener.
removeEntryListener(UUID) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
removeEntryListener(UUID) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
removeEntryListener(UUID) - Method in interface com.hazelcast.map.QueryCache
 
removeEntryListener(UUID) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
removeEntryListener(UUID) - Method in interface com.hazelcast.multimap.MultiMap
Removes the specified entry listener.
removeEntryListener(UUID) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
removeEntryListener(UUID) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Removes the specified entry listener.
removeEventHandler(long) - Method in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
removeEventListener(String, UUID) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
 
removeEventListener(String, UUID) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapEventPublishingService
 
removeFirstOccurrence(E) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
Removes the first occurrence of the specified element in this queue when searching it by starting from the head of this queue.
RemoveFromLoadAllOperation - Class in com.hazelcast.map.impl.operation
Removes keys that are contained in the RecordStore from the provided list, leaving only keys which are not contained in the record store.
RemoveFromLoadAllOperation() - Constructor for class com.hazelcast.map.impl.operation.RemoveFromLoadAllOperation
 
RemoveFromLoadAllOperation(String, List<Data>) - Constructor for class com.hazelcast.map.impl.operation.RemoveFromLoadAllOperation
 
removeFromStagingArea(DelayedEntry) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
removeIf(Predicate<? super T>) - Method in class com.hazelcast.internal.util.collection.ImmutableInflatableSet
 
removeIf(Predicate) - Method in class com.hazelcast.internal.util.ResultSet
 
removeIf(Predicate<? super E>) - Method in class com.hazelcast.map.impl.query.QueryResultCollection
 
removeIf(Predicate<? super E>) - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
 
RemoveIfSameOperation - Class in com.hazelcast.map.impl.operation
 
RemoveIfSameOperation() - Constructor for class com.hazelcast.map.impl.operation.RemoveIfSameOperation
 
RemoveIfSameOperation(String, Data, Data) - Constructor for class com.hazelcast.map.impl.operation.RemoveIfSameOperation
 
removeInterceptor(String) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
removeInterceptor(String) - Method in interface com.hazelcast.map.IMap
Removes the given interceptor for this map, so it will not intercept operations anymore.
removeInterceptor(String, String) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
 
removeInterceptor(String) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
RemoveInterceptorOperation - Class in com.hazelcast.map.impl.operation
 
RemoveInterceptorOperation() - Constructor for class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
 
RemoveInterceptorOperation(String, String) - Constructor for class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
 
RemoveInterceptorOperationSupplier - Class in com.hazelcast.map.impl.operation
 
RemoveInterceptorOperationSupplier(String, String) - Constructor for class com.hazelcast.map.impl.operation.RemoveInterceptorOperationSupplier
 
removeInternal(Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
removeInternal(Object, Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
removeInternal(Object) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
removeInternal(Object, Object) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
removeInternal(Object) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
removeInternal(Object, Data) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
removeInternal(Data, Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
removeInternal(Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
removeItemListener(UUID) - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
removeItemListener(UUID) - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
removeItemListener(UUID) - Method in class com.hazelcast.client.impl.proxy.ClientSetProxy
 
removeItemListener(UUID) - Method in interface com.hazelcast.collection.ICollection
Removes the specified item listener.
removeItemListener(UUID) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
removeItemListener(String, UUID) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
removeLifecycleListener(UUID) - Method in class com.hazelcast.client.impl.clientside.LifecycleServiceImpl
 
removeLifecycleListener(UUID) - Method in interface com.hazelcast.core.LifecycleService
Removes a lifecycle listener.
removeLifecycleListener(UUID) - Method in class com.hazelcast.instance.impl.LifecycleServiceImpl
 
removeLifecycleListener(UUID) - Method in class com.hazelcast.instance.impl.TerminatedLifecycleService
 
removeListener(CacheEntryListenerConfiguration) - Method in class com.hazelcast.cache.impl.AbstractCacheSyncListenerCompleter
 
removeListener(String, String, UUID) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheEventService
 
removeListener(String, UUID) - Method in class com.hazelcast.client.impl.querycache.subscriber.QueryCacheToListenerMapper
 
removeListener(String, String, UUID) - Method in interface com.hazelcast.map.impl.querycache.QueryCacheEventService
Removes listener from this event service.
removeListener(String, String, UUID) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheEventService
 
removeListener(String, UUID) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
removeLocalLocks() - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
removeLogListener(LogListener) - Method in class com.hazelcast.client.impl.clientside.ClientLoggingService
 
removeLogListener(LogListener) - Method in class com.hazelcast.logging.impl.LoggingServiceImpl
 
removeLogListener(LogListener) - Method in interface com.hazelcast.logging.LoggingService
 
removeMapContainer(MapContainer) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
removeMember(long, CPMemberInfo) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
this method is idempotent
removeMember(Member) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
removeMember(Member) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
removeMember(Member) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
removeMembershipListener(UUID) - Method in class com.hazelcast.client.impl.proxy.ClientClusterProxy
 
removeMembershipListener(UUID) - Method in interface com.hazelcast.client.impl.spi.ClientClusterService
 
removeMembershipListener(UUID) - Method in class com.hazelcast.client.impl.spi.impl.ClientClusterServiceImpl
 
removeMembershipListener(UUID) - Method in interface com.hazelcast.cluster.Cluster
Removes the specified MembershipListener.
removeMembershipListener(UUID) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
removeMessageListener(UUID) - Method in class com.hazelcast.client.impl.proxy.ClientReliableTopicProxy
 
removeMessageListener(UUID) - Method in class com.hazelcast.client.impl.proxy.ClientTopicProxy
 
removeMessageListener(UUID) - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicProxy
 
removeMessageListener(UUID) - Method in class com.hazelcast.topic.impl.TopicProxy
 
removeMessageListener(String, UUID) - Method in class com.hazelcast.topic.impl.TopicService
 
removeMessageListener(UUID) - Method in interface com.hazelcast.topic.ITopic
Stops receiving messages for the given message listener.
removeMessageListenerInternal(UUID) - Method in class com.hazelcast.topic.impl.TopicProxySupport
 
removeMetadata(Record) - Method in class com.hazelcast.map.impl.recordstore.JsonMetadataRecordStoreMutationObserver
 
removeMigrationListener(UUID) - Method in class com.hazelcast.client.impl.proxy.PartitionServiceProxy
 
removeMigrationListener(UUID) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
removeMigrationListener(UUID) - Method in class com.hazelcast.internal.partition.impl.PartitionEventManager
 
removeMigrationListener(UUID) - Method in class com.hazelcast.internal.partition.PartitionServiceProxy
 
removeMigrationListener(UUID) - Method in interface com.hazelcast.partition.PartitionService
Removes a MigrationListener.
removeMigrationListener(UUID) - Method in interface com.hazelcast.spi.partition.IPartitionService
 
removeModifierSuffix(String) - Static method in class com.hazelcast.query.impl.getters.SuffixModifierUtils
Remove modifier suffix from given fullName.
removeMulticastListener(MulticastListener) - Method in class com.hazelcast.internal.cluster.impl.MulticastService
 
removeNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
 
removeNotificationListener(NotificationListener) - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
 
RemoveOperation - Class in com.hazelcast.collection.impl.queue.operations
Remove operation for the Queue.
RemoveOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.RemoveOperation
 
RemoveOperation(String, Data) - Constructor for class com.hazelcast.collection.impl.queue.operations.RemoveOperation
 
removeOperation(long) - Method in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
 
RemoveOperation - Class in com.hazelcast.map.impl.operation
 
RemoveOperation() - Constructor for class com.hazelcast.map.impl.operation.RemoveOperation
 
RemoveOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.RemoveOperation
 
RemoveOperation - Class in com.hazelcast.multimap.impl.operations
 
RemoveOperation() - Constructor for class com.hazelcast.multimap.impl.operations.RemoveOperation
 
RemoveOperation(String, Data, long, Data) - Constructor for class com.hazelcast.multimap.impl.operations.RemoveOperation
 
RemoveOperation - Class in com.hazelcast.replicatedmap.impl.operation
Removes the key from replicated map.
RemoveOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.RemoveOperation
 
RemoveOperation(String, Data) - Constructor for class com.hazelcast.replicatedmap.impl.operation.RemoveOperation
 
removePartitioningStrategyFromCache(String) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
removePartitioningStrategyFromCache(String) - Method in class com.hazelcast.map.impl.PartitioningStrategyFactory
Remove the cached PartitioningStrategy from the internal cache, if it exists.
removePartitionLostListener(UUID) - Method in interface com.hazelcast.cache.ICache
Removes the specified cache partition lost listener.
removePartitionLostListener(UUID) - Method in class com.hazelcast.cache.impl.CacheProxy
 
removePartitionLostListener(UUID) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
removePartitionLostListener(UUID) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
removePartitionLostListener(UUID) - Method in class com.hazelcast.client.impl.proxy.PartitionServiceProxy
 
removePartitionLostListener(UUID) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
removePartitionLostListener(UUID) - Method in class com.hazelcast.internal.partition.impl.PartitionEventManager
 
removePartitionLostListener(UUID) - Method in class com.hazelcast.internal.partition.PartitionServiceProxy
 
removePartitionLostListener(UUID) - Method in interface com.hazelcast.map.IMap
Removes the specified map partition lost listener.
removePartitionLostListener(String, UUID) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
 
removePartitionLostListener(UUID) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
removePartitionLostListener(UUID) - Method in interface com.hazelcast.partition.PartitionService
Removes a PartitionLostListener.
removePartitionLostListener(UUID) - Method in interface com.hazelcast.spi.partition.IPartitionService
 
RemovePartitionLostListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task
 
RemovePartitionLostListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
 
removeProperty(String) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
removeProxyListener(UUID) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
 
removeProxyListener(UUID) - Method in interface com.hazelcast.spi.impl.proxyservice.ProxyService
 
removePublisherListener(String, String, UUID) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheEventService
 
removePublisherListener(String, String, UUID) - Method in interface com.hazelcast.map.impl.querycache.QueryCacheEventService
Removes listener from underlying IMap
removePublisherListener(String, String, UUID) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheEventService
 
removeQueue(int) - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
 
removeRaftStateStore(RaftGroupId) - Method in interface com.hazelcast.cp.internal.persistence.CPPersistenceService
Removes the store associated with groupId, removes all persisted state and releases acquired resources.
removeRaftStateStore(RaftGroupId) - Method in class com.hazelcast.cp.internal.persistence.NopCPPersistenceService
 
removeRecord(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
removeRecord(Data) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Removes the record for a key.
removeRecord(Data, Record, long, CallerProvenance, UUID) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
removeRecord(R) - Method in interface com.hazelcast.map.impl.recordstore.Storage
 
removeRecord(R) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
removeRecords(Collection<Record>) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
removeRecordStoresFromPartitionMatchingWith(Predicate<RecordStore>, int, boolean, boolean) - Method in interface com.hazelcast.map.impl.MapServiceContext
Removes all record stores inside the supplied partition ID matching with the supplied predicate.
removeRegistration(String, UUID) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceSegment
Removes the registration matching the topic and ID.
removeSingleQueryCache(String, String) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheEndToEndProvider
 
removeThreadId() - Static method in class com.hazelcast.internal.util.ThreadUtil
Remove the thread ID.
removeTimeTakenNanos - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
removeTransactionContext(UUID) - Method in interface com.hazelcast.client.impl.ClientEndpoint
 
removeTransactionContext(UUID) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
removeTransactions(SerializableXID) - Method in class com.hazelcast.transaction.impl.xa.XAService
 
removeTxn(Data, CallerProvenance, UUID) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
removeTxn(Data, CallerProvenance, UUID) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
removeUuidAndSequence(int) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataGenerator
 
removeWaitKey(Object) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.BlockingResource
 
removeWaitKey(String, W) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
removeWanEventCounters(String, String) - Method in interface com.hazelcast.wan.impl.WanReplicationService
Removes all WAN event counters for the given serviceName and dataStructureName.
removeWanEventCounters(String, String) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
 
removeWanEvents(int, String, String, int) - Method in interface com.hazelcast.wan.impl.InternalWanReplicationPublisher
Removes a count number of events pending replication and belonging to the provided service, object and partition.
removeWanEvents(String, String) - Method in interface com.hazelcast.wan.impl.WanReplicationService
Removes all WAN events awaiting replication for the given wanReplicationName for the given target.
removeWanEvents(String, String) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
 
removeWanEvents() - Method in interface com.hazelcast.wan.WanReplicationPublisher
Removes all WAN events awaiting replication.
removeWanEvents(int, String) - Method in interface com.hazelcast.wan.WanReplicationPublisher
Removes all WAN events awaiting replication and belonging to the provided service and partition.
removeWbqCountersFromMatchingPartitionsWith(Predicate<RecordStore>, int) - Method in interface com.hazelcast.map.impl.MapServiceContext
Removes write-behind-queue-reservation-counters inside supplied partition from matching record-stores.
removeWithVersion(Object, long) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
removeWithVersion(Object, long) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
rename(File, File) - Static method in class com.hazelcast.internal.nio.IOUtil
Ensures that the file described by fileNow is renamed to file described by fileToBe.
render(StringBuilder) - Method in interface com.hazelcast.internal.metrics.Gauge
Renders the value from the gauge.
RepairingHandler - Class in com.hazelcast.internal.nearcache.impl.invalidation
Handler used on Near Cache side.
RepairingHandler(ILogger, UUID, String, NearCache, SerializationService, MinimalPartitionService) - Constructor for class com.hazelcast.internal.nearcache.impl.invalidation.RepairingHandler
 
RepairingTask - Class in com.hazelcast.internal.nearcache.impl.invalidation
This task runs on Near Cache side and only one instance is created per data-structure type like IMap and ICache.
RepairingTask(HazelcastProperties, InvalidationMetaDataFetcher, TaskScheduler, SerializationService, MinimalPartitionService, UUID, ILogger) - Constructor for class com.hazelcast.internal.nearcache.impl.invalidation.RepairingTask
 
repairingTask - Variable in class com.hazelcast.map.impl.nearcache.MapNearCacheManager
 
replace(K, V, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Atomically replaces the currently assigned value for the given key with the specified newValue if and only if the currently assigned value equals the value of oldValue using a custom ExpiryPolicy.
replace(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Atomically replaces the assigned value of the given key by the specified value using a custom ExpiryPolicy.
replace(Data, Object, ExpiryPolicy, UUID, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
replace(Data, Object, Object, ExpiryPolicy, UUID, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
REPLACE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
replace(K, V, V) - Method in class com.hazelcast.cache.impl.CacheProxy
 
replace(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
 
replace(K, V, V, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.CacheProxy
 
replace(K, V, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.CacheProxy
 
replace(Data, Object, ExpiryPolicy, UUID, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Atomically replaces the entry for a key only if currently mapped to some value.
replace(Data, Object, Object, ExpiryPolicy, UUID, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Atomically replaces the entry for a key only if currently mapped to a given value.
replace(K, V, V) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
replace(K, V) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
replace(K, V, V, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
replace(K, V, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
replace(K, V, V) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
replace(K, V) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
replace(K, V) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
replace(K, V, V) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
replace(K, V) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
replace(K, V, V) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
replace(K, V) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
replace(K, V, V) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
replace(K, V) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
replace(K, V, V) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
replace(K, V) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
replace(K, V, V) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
replace(K, V) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
replace(K, V, V) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
replace(String, String, Object) - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
replace(String, String, Object) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
replace(InboundHandler, InboundHandler...) - Method in interface com.hazelcast.internal.networking.InboundPipeline
Replaces the old InboundHandler by the new ones.
replace(InboundHandler, InboundHandler...) - Method in class com.hazelcast.internal.networking.nio.NioInboundPipeline
 
replace(OutboundHandler, OutboundHandler...) - Method in class com.hazelcast.internal.networking.nio.NioOutboundPipeline
 
replace(OutboundHandler, OutboundHandler...) - Method in interface com.hazelcast.internal.networking.OutboundPipeline
Replaces the old OutboundHandler by the new ones.
replace(long, long, long) - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
 
replace(long, long) - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
 
replace(long, long, long) - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
 
replace(long, long) - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
 
replace(K, V, V) - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
replace(K, V) - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
replace(K, V) - Method in interface com.hazelcast.map.BaseMap
Replaces the entry for a key only if it is currently mapped to some value.
replace(K, V, V) - Method in interface com.hazelcast.map.BaseMap
Replaces the entry for a key only if currently mapped to a given value.
replace(K, V, V) - Method in interface com.hazelcast.map.IMap
Replaces the entry for a key only if currently mapped to a given value.
replace(K, V) - Method in interface com.hazelcast.map.IMap
Replaces the entry for a key only if it is currently mapped to some value.
REPLACE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
replace(K, V, V) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
replace(K, V) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
replace(Data, Object) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
replace(Data, Object, Object) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
replace(Data, Object) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
replace(Data, Object, Object) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Sets the value to the given updated value if ValueComparator.isEqual(java.lang.Object, java.lang.Object, com.hazelcast.internal.serialization.SerializationService) comparison of current value and expected value is true.
replace(Object, Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
replace(Object, Object, Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
replace(K, V) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.replace(Object, Object).
replace(K, V, V) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.replace(Object, Object, Object).
REPLACE_IF_SAME - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
replaceAsync(K, V) - Method in interface com.hazelcast.cache.ICache
Asynchronously replaces the assigned value of the given key by the specified value.
replaceAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Asynchronously replaces the assigned value of the given key by the specified value using a custom ExpiryPolicy.
replaceAsync(K, V, V) - Method in interface com.hazelcast.cache.ICache
Asynchronously replaces the currently assigned value for the given key with the specified newValue if and only if the currently assigned value equals the value of oldValue.
replaceAsync(K, V, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Asynchronously replaces the currently assigned value for the given key with the specified newValue if and only if the currently assigned value equals the value of oldValue using a custom ExpiryPolicy.
replaceAsync(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
 
replaceAsync(K, V, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.CacheProxy
 
replaceAsync(K, V, V) - Method in class com.hazelcast.cache.impl.CacheProxy
 
replaceAsync(K, V, V, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.CacheProxy
 
replaceAsync(K, V) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
replaceAsync(K, V, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
replaceAsync(K, V, V) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
replaceAsync(K, V, V, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
replaceChild(Node, Node) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
replaceExistingValues - Variable in class com.hazelcast.client.impl.protocol.codec.CacheLoadAllCodec.RequestParameters
when true existing values in the Cache will be replaced by those loaded from a CacheLoader
replaceExistingValues - Variable in class com.hazelcast.client.impl.protocol.codec.MapLoadAllCodec.RequestParameters
when true, existing values in the Map will be replaced by those loaded from the MapLoader
replaceExistingValues - Variable in class com.hazelcast.client.impl.protocol.codec.MapLoadGivenKeysCodec.RequestParameters
when true, existing values in the Map will be replaced by those loaded from the MapLoader
replaceFirst(T[], T, T[]) - Static method in class com.hazelcast.internal.util.collection.ArrayUtils
Replaces the first occurrence of the oldValue by the newValue.
replaceIfSameInternal(Object, Object, Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
replaceIfSameInternal(Object, Object, Object) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
ReplaceIfSameOperation - Class in com.hazelcast.map.impl.operation
 
ReplaceIfSameOperation() - Constructor for class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
 
ReplaceIfSameOperation(String, Data, Data, Data) - Constructor for class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
 
replaceInternal(Object, Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
replaceInternal(Object, Object) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
replaceInternal(Object, Data, Data) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
replaceInternal(Object, Data) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
replaceMember(Member, Member) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
ReplaceOperation - Class in com.hazelcast.map.impl.operation
 
ReplaceOperation(String, Data, Data) - Constructor for class com.hazelcast.map.impl.operation.ReplaceOperation
 
ReplaceOperation() - Constructor for class com.hazelcast.map.impl.operation.ReplaceOperation
 
replaceVariables(Node) - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
 
REPLICA_FRAGMENT_MIGRATION_STATE - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
REPLICA_MIGRATION_EVENT - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
REPLICA_SYNC_REQUEST - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
REPLICA_SYNC_RESPONSE - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
REPLICA_SYNC_RETRY_RESPONSE - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
replicaBackupLog(List<TransactionLogRecord>, UUID, UUID, long, long) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
replicaChanged(int, int, PartitionReplica, PartitionReplica) - Method in class com.hazelcast.internal.partition.impl.NopPartitionReplicaInterceptor
 
replicaChanged(int, int, PartitionReplica, PartitionReplica) - Method in interface com.hazelcast.internal.partition.PartitionReplicaInterceptor
Called when a new partition arrangement has been set and a partition replica has been changed.
replicaCount - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddPNCounterConfigCodec.RequestParameters
number of replicas on which the CRDT state is kept
replicaCount - Variable in class com.hazelcast.client.impl.protocol.codec.PNCounterAddCodec.ResponseParameters
TODO DOC
replicaCount - Variable in class com.hazelcast.client.impl.protocol.codec.PNCounterGetCodec.ResponseParameters
TODO DOC
ReplicaErrorLogger - Class in com.hazelcast.internal.partition
 
ReplicaFragmentMigrationState - Class in com.hazelcast.internal.partition
Contains fragment namespaces along with their partition versions and migration data operations
ReplicaFragmentMigrationState() - Constructor for class com.hazelcast.internal.partition.ReplicaFragmentMigrationState
 
ReplicaFragmentMigrationState(Map<ServiceNamespace, long[]>, Collection<Operation>) - Constructor for class com.hazelcast.internal.partition.ReplicaFragmentMigrationState
 
ReplicaFragmentSyncInfo - Class in com.hazelcast.internal.partition.impl
The information for a replica synchronization - which partition and replica index needs synchronization and what is the target (the owner of the partition).
replicaIndex - Variable in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
 
replicaIndices() - Static method in interface com.hazelcast.internal.partition.InternalPartition
Returns the integer replica indices of InternalPartition as a stream.
replicaMigrationCompleted(ReplicaMigrationEvent) - Method in interface com.hazelcast.partition.MigrationListener
Called when a partition replica migration is completed successfully.
ReplicaMigrationEvent - Interface in com.hazelcast.partition
An event fired when a partition replica migration completes or fails.
ReplicaMigrationEventImpl - Class in com.hazelcast.internal.partition
An event fired when a partition migration starts, completes or fails.
ReplicaMigrationEventImpl() - Constructor for class com.hazelcast.internal.partition.ReplicaMigrationEventImpl
 
ReplicaMigrationEventImpl(MigrationState, int, int, Member, Member, boolean, long) - Constructor for class com.hazelcast.internal.partition.ReplicaMigrationEventImpl
 
replicaMigrationFailed(ReplicaMigrationEvent) - Method in interface com.hazelcast.partition.MigrationListener
Called when a partition replica migration is failed.
replicate(RaftNode) - Method in class com.hazelcast.cp.internal.operation.ChangeRaftGroupMembershipOp
 
replicate(RaftNode) - Method in class com.hazelcast.cp.internal.operation.DefaultRaftReplicateOp
 
replicate(RaftNode) - Method in class com.hazelcast.cp.internal.operation.DestroyRaftGroupOp
 
replicate(RaftNode) - Method in class com.hazelcast.cp.internal.operation.RaftReplicateOp
 
replicate(Object) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Replicates the given operation to the Raft group.
replicate(Object) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
REPLICATE_ALLOWED_DURING_PASSIVE_STATE_TX_BACKUP_LOG - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
REPLICATE_TX_BACKUP_LOG - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
REPLICATE_UPDATE - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
REPLICATE_UPDATE_TO_CALLER - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
ReplicateAllowedDuringPassiveStateTxBackupLogOperation - Class in com.hazelcast.transaction.impl.operations
 
ReplicateAllowedDuringPassiveStateTxBackupLogOperation() - Constructor for class com.hazelcast.transaction.impl.operations.ReplicateAllowedDuringPassiveStateTxBackupLogOperation
 
ReplicateAllowedDuringPassiveStateTxBackupLogOperation(Collection<TransactionLogRecord>, UUID, UUID, long, long) - Constructor for class com.hazelcast.transaction.impl.operations.ReplicateAllowedDuringPassiveStateTxBackupLogOperation
 
REPLICATED_MAP_CANT_BE_CREATED - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
REPLICATED_MAP_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
REPLICATED_MAP_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
REPLICATED_MAP_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
REPLICATED_MAP_MERGING_ENTRY - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
REPLICATED_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
REPLICATED_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ReplicatedEntryEventFilter - Class in com.hazelcast.replicatedmap.impl.record
Basic filter implementation for selecting interesting events on the server
ReplicatedEntryEventFilter(Data) - Constructor for class com.hazelcast.replicatedmap.impl.record.ReplicatedEntryEventFilter
 
ReplicatedMap<K,V> - Interface in com.hazelcast.replicatedmap
A ReplicatedMap is a map-like data structure with weak consistency and values locally stored on every node of the cluster.
ReplicatedMapAddEntryListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds an entry listener for this map.
ReplicatedMapAddEntryListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapAddEntryListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapAddEntryListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapAddEntryListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
 
ReplicatedMapAddEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
 
ReplicatedMapAddEntryListenerToKeyCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds the specified entry listener for the specified key.
ReplicatedMapAddEntryListenerToKeyCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapAddEntryListenerToKeyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapAddEntryListenerToKeyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapAddEntryListenerToKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
 
ReplicatedMapAddEntryListenerToKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
 
ReplicatedMapAddEntryListenerToKeyWithPredicateCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds an continuous entry listener for this map.
ReplicatedMapAddEntryListenerToKeyWithPredicateCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapAddEntryListenerToKeyWithPredicateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapAddEntryListenerToKeyWithPredicateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
 
ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
 
ReplicatedMapAddEntryListenerWithPredicateCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds an continuous entry listener for this map.
ReplicatedMapAddEntryListenerWithPredicateCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapAddEntryListenerWithPredicateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapAddEntryListenerWithPredicateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapAddEntryListenerWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
 
ReplicatedMapAddEntryListenerWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
 
ReplicatedMapAddNearCacheEntryListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ReplicatedMapAddNearCacheEntryListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapAddNearCacheEntryListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapAddNearCacheEntryListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapAddNearCacheListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
 
ReplicatedMapAddNearCacheListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
 
ReplicatedMapCantBeCreatedOnLiteMemberException - Exception in com.hazelcast.replicatedmap
Thrown when HazelcastInstance.getReplicatedMap(String) is invoked on a lite member.
ReplicatedMapCantBeCreatedOnLiteMemberException(Address) - Constructor for exception com.hazelcast.replicatedmap.ReplicatedMapCantBeCreatedOnLiteMemberException
 
ReplicatedMapCantBeCreatedOnLiteMemberException(String) - Constructor for exception com.hazelcast.replicatedmap.ReplicatedMapCantBeCreatedOnLiteMemberException
 
ReplicatedMapClearCodec - Class in com.hazelcast.client.impl.protocol.codec
The clear operation wipes data out of the replicated maps.It is the only synchronous remote operation in this implementation, so be aware that this might be a slow operation.
ReplicatedMapClearCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapClearCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapClearMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
 
ReplicatedMapClearMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
 
ReplicatedMapConfig - Class in com.hazelcast.config
Contains the configuration for an ReplicatedMap
ReplicatedMapConfig() - Constructor for class com.hazelcast.config.ReplicatedMapConfig
 
ReplicatedMapConfig(String) - Constructor for class com.hazelcast.config.ReplicatedMapConfig
Creates a ReplicatedMapConfig with the given name.
ReplicatedMapConfig(ReplicatedMapConfig) - Constructor for class com.hazelcast.config.ReplicatedMapConfig
 
replicatedMapConfig - Variable in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
ReplicatedMapConfigReadOnly - Class in com.hazelcast.internal.config
 
ReplicatedMapConfigReadOnly(ReplicatedMapConfig) - Constructor for class com.hazelcast.internal.config.ReplicatedMapConfigReadOnly
 
ReplicatedMapContainsKeyCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns true if this map contains a mapping for the specified key.
ReplicatedMapContainsKeyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapContainsKeyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapContainsKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
 
ReplicatedMapContainsKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
 
ReplicatedMapContainsValueCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns true if this map maps one or more keys to the specified value.
ReplicatedMapContainsValueCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapContainsValueCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapContainsValueMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
 
ReplicatedMapContainsValueMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
 
ReplicatedMapDataSerializerHook - Class in com.hazelcast.replicatedmap.impl.operation
This class contains all the ID hooks for IdentifiedDataSerializable classes used inside the replicated map.
ReplicatedMapDataSerializerHook() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
ReplicatedMapDataStructureAdapter<K,V> - Class in com.hazelcast.internal.adapter
 
ReplicatedMapDataStructureAdapter(ReplicatedMap<K, V>) - Constructor for class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
ReplicatedMapEntries - Class in com.hazelcast.replicatedmap.impl.client
An implementation of a portable implementing entry set for client results on entrySet requests
ReplicatedMapEntries() - Constructor for class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
 
ReplicatedMapEntries(int) - Constructor for class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
 
ReplicatedMapEntries(List<Map.Entry<Data, Data>>) - Constructor for class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
 
ReplicatedMapEntrySetCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ReplicatedMapEntrySetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapEntrySetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapEntrySetMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
 
ReplicatedMapEntrySetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
 
ReplicatedMapEntryView<K,V> - Class in com.hazelcast.replicatedmap.impl.record
 
ReplicatedMapEntryView() - Constructor for class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
ReplicatedMapEntryView(SerializationService) - Constructor for class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
ReplicatedMapEventPublishingService - Class in com.hazelcast.replicatedmap.impl
Dispatches published events on replicated map to corresponding listeners.
ReplicatedMapEventPublishingService(ReplicatedMapService) - Constructor for class com.hazelcast.replicatedmap.impl.ReplicatedMapEventPublishingService
 
ReplicatedMapEvictionProcessor - Class in com.hazelcast.replicatedmap.impl
Actual eviction processor implementation to remove values to evict values from the replicated map
ReplicatedMapEvictionProcessor(ReplicatedRecordStore, NodeEngine, int) - Constructor for class com.hazelcast.replicatedmap.impl.ReplicatedMapEvictionProcessor
 
ReplicatedMapGetCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
ReplicatedMapGetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapGetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
 
ReplicatedMapGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
 
ReplicatedMapIsEmptyCodec - Class in com.hazelcast.client.impl.protocol.codec
Return true if this map contains no key-value mappings
ReplicatedMapIsEmptyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapIsEmptyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapIsEmptyMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
 
ReplicatedMapIsEmptyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
 
ReplicatedMapKeys - Class in com.hazelcast.replicatedmap.impl.client
Class to implement a replicated map keySet result
ReplicatedMapKeys() - Constructor for class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeys
 
ReplicatedMapKeys(List<Data>) - Constructor for class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeys
 
ReplicatedMapKeySetCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns a lazy Set view of the key contained in this map.
ReplicatedMapKeySetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapKeySetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapKeySetMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
 
ReplicatedMapKeySetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
 
ReplicatedMapMBean - Class in com.hazelcast.internal.jmx
Management bean for ReplicatedMap
ReplicatedMapMBean(ReplicatedMapProxy, ManagementService) - Constructor for class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
ReplicatedMapMergingEntryImpl - Class in com.hazelcast.spi.impl.merge
ReplicatedMapMergingEntryImpl() - Constructor for class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
ReplicatedMapMergingEntryImpl(SerializationService) - Constructor for class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
ReplicatedMapPermission - Class in com.hazelcast.security.permission
 
ReplicatedMapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ReplicatedMapPermission
 
ReplicatedMapPortableEntryEvent - Class in com.hazelcast.replicatedmap.impl.client
Class to redirect entry listener events on the members to the listening client
ReplicatedMapPortableHook - Class in com.hazelcast.replicatedmap.impl.client
This class registers all Portable serializers that are needed for communication between nodes and clients
ReplicatedMapPortableHook() - Constructor for class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
 
ReplicatedMapProxy<K,V> - Class in com.hazelcast.replicatedmap.impl
Proxy implementation of ReplicatedMap interface.
ReplicatedMapPutAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Copies all of the mappings from the specified map to this map (optional operation).
ReplicatedMapPutAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapPutAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapPutAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
 
ReplicatedMapPutAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
 
ReplicatedMapPutCodec - Class in com.hazelcast.client.impl.protocol.codec
Associates a given value to the specified key and replicates it to the cluster.
ReplicatedMapPutCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapPutCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapPutMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
 
ReplicatedMapPutMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
 
ReplicatedMapRemoveCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the mapping for a key from this map if it is present (optional operation).
ReplicatedMapRemoveCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapRemoveCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapRemoveEntryListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the specified entry listener.
ReplicatedMapRemoveEntryListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapRemoveEntryListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapRemoveEntryListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
 
ReplicatedMapRemoveEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
 
ReplicatedMapRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
 
ReplicatedMapRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
 
replicatedMapService - Variable in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
ReplicatedMapService - Class in com.hazelcast.replicatedmap.impl
This is the main service implementation to handle proxy creation, event publishing, migration, anti-entropy and manages the backing PartitionContainers that actually hold the data
ReplicatedMapService(NodeEngine) - Constructor for class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
ReplicatedMapSizeCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the number of key-value mappings in this map.
ReplicatedMapSizeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapSizeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
 
ReplicatedMapSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
 
ReplicatedMapValueCollection - Class in com.hazelcast.replicatedmap.impl.client
Class implementing a replicated map value collection result
ReplicatedMapValueCollection(Collection<Data>) - Constructor for class com.hazelcast.replicatedmap.impl.client.ReplicatedMapValueCollection
 
ReplicatedMapValuesCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
ReplicatedMapValuesCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapValuesCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ReplicatedMapValuesMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
 
ReplicatedMapValuesMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
 
ReplicatedQueryEventFilter - Class in com.hazelcast.replicatedmap.impl.record
This class is used to transfer a predicate as an remote operation and filter values matching the predicate
ReplicatedQueryEventFilter(Data, Predicate) - Constructor for class com.hazelcast.replicatedmap.impl.record.ReplicatedQueryEventFilter
 
ReplicatedRecord<K,V> - Class in com.hazelcast.replicatedmap.impl.record
A ReplicatedRecord is the actual data holding entity.
ReplicatedRecord(K, V, long) - Constructor for class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
ReplicatedRecordStore - Interface in com.hazelcast.replicatedmap.impl.record
This interface describes a common record store for replicated maps and their actual records
replicateMembershipChange(RaftEndpoint, MembershipChangeMode) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Replicates the membership change to the Raft group.
replicateMembershipChange(RaftEndpoint, MembershipChangeMode, long) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Replicates the membership change to the Raft group, if expected members commit index is equal to the actual one stored in Raft state.
replicateMembershipChange(RaftEndpoint, MembershipChangeMode) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
replicateMembershipChange(RaftEndpoint, MembershipChangeMode, long) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
ReplicateTask - Class in com.hazelcast.cp.internal.raft.impl.task
ReplicateTask is executed to append an operation to Raft log and replicate the new entry to followers.
ReplicateTask(RaftNodeImpl, Object, InternalCompletableFuture) - Constructor for class com.hazelcast.cp.internal.raft.impl.task.ReplicateTask
 
ReplicateTxBackupLogOperation - Class in com.hazelcast.transaction.impl.operations
Replicates the transactionlog to a remote system.
ReplicateTxBackupLogOperation() - Constructor for class com.hazelcast.transaction.impl.operations.ReplicateTxBackupLogOperation
 
ReplicateTxBackupLogOperation(Collection<TransactionLogRecord>, UUID, UUID, long, long) - Constructor for class com.hazelcast.transaction.impl.operations.ReplicateTxBackupLogOperation
 
ReplicateUpdateOperation - Class in com.hazelcast.replicatedmap.impl.operation
Replicates the update happened on the partition owner to the other nodes.
ReplicateUpdateOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateOperation
 
ReplicateUpdateOperation(String, Data, Data, long, VersionResponsePair, boolean, Address) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateOperation
 
ReplicateUpdateToCallerOperation - Class in com.hazelcast.replicatedmap.impl.operation
This operation will update the local record store with the update received from local/remote partition owner.
ReplicateUpdateToCallerOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateToCallerOperation
 
ReplicateUpdateToCallerOperation(String, long, Data, Data, VersionResponsePair, long, boolean) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateToCallerOperation
 
replicaTimestamps - Variable in class com.hazelcast.client.impl.protocol.codec.PNCounterAddCodec.RequestParameters
last observed replica timestamps (vector clock)
replicaTimestamps - Variable in class com.hazelcast.client.impl.protocol.codec.PNCounterAddCodec.ResponseParameters
last observed replica timestamps (vector clock)
replicaTimestamps - Variable in class com.hazelcast.client.impl.protocol.codec.PNCounterGetCodec.RequestParameters
last observed replica timestamps (vector clock)
replicaTimestamps - Variable in class com.hazelcast.client.impl.protocol.codec.PNCounterGetCodec.ResponseParameters
last observed replica timestamps (vector clock)
REPLICATION - Static variable in class com.hazelcast.cardinality.impl.CardinalityEstimatorDataSerializerHook
 
REPLICATION - Static variable in class com.hazelcast.durableexecutor.impl.DurableExecutorDataSerializerHook
 
REPLICATION - Static variable in class com.hazelcast.internal.longregister.LongRegisterDataSerializerHook
 
REPLICATION - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
REPLICATION - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
REPLICATION_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
 
ReplicationOperation - Class in com.hazelcast.cardinality.impl.operations
 
ReplicationOperation() - Constructor for class com.hazelcast.cardinality.impl.operations.ReplicationOperation
 
ReplicationOperation(Map<String, CardinalityEstimatorContainer>) - Constructor for class com.hazelcast.cardinality.impl.operations.ReplicationOperation
 
ReplicationOperation - Class in com.hazelcast.durableexecutor.impl.operations
 
ReplicationOperation() - Constructor for class com.hazelcast.durableexecutor.impl.operations.ReplicationOperation
 
ReplicationOperation(Map<String, DurableExecutorContainer>) - Constructor for class com.hazelcast.durableexecutor.impl.operations.ReplicationOperation
 
ReplicationOperation - Class in com.hazelcast.replicatedmap.impl.operation
Carries all the partition data for replicated map from old owner to the new owner.
ReplicationOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicationOperation
 
ReplicationOperation(SerializationService, PartitionContainer, int) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicationOperation
 
ReplicationOperation - Class in com.hazelcast.ringbuffer.impl.operations
 
ReplicationOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.ReplicationOperation
 
ReplicationOperation(Map<ObjectNamespace, RingbufferContainer>, int, int) - Constructor for class com.hazelcast.ringbuffer.impl.operations.ReplicationOperation
 
ReplicationOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
ReplicationOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.ReplicationOperation
 
ReplicationOperation(Map<String, Map<String, ScheduledTaskDescriptor>>) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.ReplicationOperation
 
ReplicationSupportingService - Interface in com.hazelcast.internal.services
An interface that can be implemented by SPI services to give them the ability to listen to WAN replication events.
replicationSupportingService - Variable in class com.hazelcast.map.impl.MapService
 
republishReplicationEvent(WanReplicationEvent) - Method in class com.hazelcast.wan.impl.DelegatingWanReplicationScheme
Publishes a replication event to all publishers to which this publisher delegates.
republishReplicationEvent(WanReplicationEvent) - Method in interface com.hazelcast.wan.WanReplicationPublisher
Publishes the wanReplicationEvent on this publisher.
request - Variable in class com.hazelcast.map.impl.querycache.subscriber.AbstractQueryCacheEndToEndConstructor
 
REQUEST_MAP_DATA - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongAddAndGetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongAlterCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongApplyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongCompareAndSetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndAddCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndSetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefApplyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefCompareAndSetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefContainsCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefGetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefSetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheAddEntryListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheAddInvalidationListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheAddNearCacheInvalidationListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheAddPartitionLostListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheAssignAndGetUuidsCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheClearCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheContainsKeyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheCreateConfigCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheDestroyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheEntryProcessorCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalReadCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalSubscribeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheFetchNearCacheInvalidationMetadataCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAndRemoveCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAndReplaceCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheGetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheGetConfigCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheIterateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheIterateEntriesCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheListenerRegistrationCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheLoadAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheManagementConfigCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CachePutAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CachePutCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CachePutIfAbsentCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllKeysCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveEntryListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveInvalidationListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheRemovePartitionLostListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheReplaceCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheSetExpiryPolicyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheSizeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorAddCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorEstimateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientAddDistributedObjectListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientAddMembershipListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionLostListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientCreateProxiesCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientCreateProxyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientDeployClassesCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientDestroyProxyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientGetDistributedObjectsCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientGetPartitionsCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientIsFailoverSupportedCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientLocalBackupListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientPingCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientRemoveAllListenersCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientRemoveDistributedObjectListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientRemovePartitionLostListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientStatisticsCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryAddListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryDestroyCacheCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryMadePublishableCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateWithValueCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQuerySetReadCursorCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchAwaitCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchCountDownCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetCountCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetRoundCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchTrySetCountCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CPGroupCreateCPGroupCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CPGroupDestroyCPObjectCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CPSessionCloseSessionCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CPSessionCreateSessionCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CPSessionGenerateThreadIdCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CPSessionHeartbeatSessionCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorDisposeResultCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorIsShutdownCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveAndDisposeResultCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveResultCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorShutdownCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorSubmitToPartitionCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCardinalityEstimatorConfigCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddDurableExecutorConfigCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddExecutorConfigCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddFlakeIdGeneratorConfigCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddListConfigCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMultiMapConfigCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddPNCounterConfigCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddQueueConfigCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReliableTopicConfigCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReplicatedMapConfigCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddRingbufferConfigCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddScheduledExecutorConfigCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddSetConfigCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddTopicConfigCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnAddressCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnPartitionCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceIsShutdownCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceShutdownCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToAddressCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToPartitionCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.FencedLockGetLockOwnershipCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.FencedLockLockCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.FencedLockTryLockCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.FencedLockUnlockCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.FlakeIdGeneratorNewIdBatchCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListAddAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListAddAllWithIndexCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListAddCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListAddListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListAddWithIndexCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListClearCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListCompareAndRemoveAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListCompareAndRetainAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListContainsAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListContainsCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListGetAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListGetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListIndexOfCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListIsEmptyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListIteratorCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListLastIndexOfCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListListIteratorCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListRemoveCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListRemoveListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListRemoveWithIndexCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListSetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListSizeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListSubCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyWithPredicateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerWithPredicateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAddIndexCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAddInterceptorCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheEntryListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheInvalidationListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAddPartitionLostListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAggregateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAggregateWithPredicateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAssignAndGetUuidsCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapClearCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapClearNearCacheCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapContainsKeyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapContainsValueCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapDeleteCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPagingPredicateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPredicateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapEntrySetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapEventJournalReadCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapEventJournalSubscribeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapEvictAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapEvictCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnAllKeysCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeysCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteWithPredicateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapFetchEntriesCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapFetchKeysCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapFetchNearCacheInvalidationMetadataCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapFetchWithQueryCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapFlushCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapForceUnlockCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapGetAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapGetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapGetEntryViewCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapIsEmptyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapIsLockedCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapKeySetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPagingPredicateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPredicateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapLoadAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapLoadGivenKeysCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapLockCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapProjectCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapProjectWithPredicateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapPutAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapPutCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentWithMaxIdleCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapPutTransientCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapPutTransientWithMaxIdleCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapPutWithMaxIdleCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveEntryListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveIfSameCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveInterceptorCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapRemovePartitionLostListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapReplaceCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapReplaceIfSameCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapSetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapSetTtlCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapSetWithMaxIdleCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapSizeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapSubmitToKeyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapTryLockCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapTryPutCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapTryRemoveCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapUnlockCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapValuesCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapValuesWithPagingPredicateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapValuesWithPredicateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MetricsReadMetricsCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerToKeyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapClearCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsEntryCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsKeyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsValueCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapDeleteCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapEntrySetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapForceUnlockCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapGetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapIsLockedCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapKeySetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapLockCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapPutCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapSizeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapTryLockCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapUnlockCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapValueCountCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapValuesCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.PNCounterAddCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.PNCounterGetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.PNCounterGetConfiguredReplicaCountCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueAddAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueAddListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueClearCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRemoveAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRetainAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueContainsAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueContainsCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueDrainToCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueDrainToMaxSizeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueIsEmptyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueIteratorCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueOfferCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueuePeekCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueuePollCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueuePutCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueRemainingCapacityCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueRemoveCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueRemoveListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueSizeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueTakeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyWithPredicateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerWithPredicateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddNearCacheEntryListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapClearCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsKeyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsValueCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapEntrySetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapGetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapIsEmptyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapKeySetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveEntryListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapSizeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapValuesCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.RingbufferAddAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.RingbufferAddCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.RingbufferCapacityCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.RingbufferHeadSequenceCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.RingbufferReadManyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.RingbufferReadOneCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.RingbufferRemainingCapacityCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.RingbufferSizeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.RingbufferTailSequenceCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromAddressCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromPartitionCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromAddressCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromPartitionCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetAllScheduledFuturesCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromAddressCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromPartitionCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromAddressCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromPartitionCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromAddressCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromPartitionCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromAddressCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromPartitionCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromAddressCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromPartitionCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorShutdownCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToAddressCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToPartitionCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreAcquireCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreAvailablePermitsCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreChangeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreDrainCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreGetSemaphoreTypeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreInitCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreReleaseCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetAddAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetAddCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetAddListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetClearCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetCompareAndRemoveAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetCompareAndRetainAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetContainsAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetContainsCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetGetAllCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetIsEmptyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetRemoveCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetRemoveListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetSizeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TopicAddMessageListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TopicPublishCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TopicRemoveMessageListenerCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListAddCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListRemoveCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListSizeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsKeyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsValueCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapDeleteCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetForUpdateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapIsEmptyCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetWithPredicateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutIfAbsentCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveIfSameCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceIfSameCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSizeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesWithPredicateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapGetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapPutCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveEntryCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapSizeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapValueCountCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueOfferCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePeekCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePollCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueSizeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueTakeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetAddCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetRemoveCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetSizeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionCommitCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionCreateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionRollbackCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.XATransactionClearRemoteCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.XATransactionCollectTransactionsCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.XATransactionCommitCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.XATransactionCreateCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.XATransactionFinalizeCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.XATransactionPrepareCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.XATransactionRollbackCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterAddAndGetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterDecrementAndGetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndAddCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndIncrementCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndSetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterIncrementAndGetCodec
 
REQUEST_MESSAGE_TYPE - Static variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterSetCodec
 
REQUEST_TYPE_CACHE_ENTRY - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_CHANGE_CLUSTER_STATE - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_CLEAR_WAN_QUEUES - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_CLUSTER_PROPERTIES - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_CLUSTER_SHUTDOWN - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_CLUSTER_STATE - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_CONSOLE_COMMAND - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_EVICT_LOCAL_MAP - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_EXECUTE_SCRIPT - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_FORCE_START_NODE - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_GET_CLUSTER_STATE - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_GET_THREAD_DUMP - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_LOG_VERSION_MISMATCH - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_LOGS - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_MAP_CONFIG - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_MAP_ENTRY - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_MEMBER_CONFIG - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_MEMBER_SHUTDOWN - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_MEMBER_SYSTEM_PROPERTIES - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_PROMOTE_MEMBER - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_RUN_GC - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_SYSTEM_WARNINGS - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_TRIGGER_PARTIAL_START - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_WAN_CHECK_CONSISTENCY - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
REQUEST_TYPE_WAN_PUBLISHER - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
 
RequestMapDataOperation - Class in com.hazelcast.replicatedmap.impl.operation
Collects and sends the replicated map data from the executing node to the caller via SyncReplicatedMapDataOperation.
RequestMapDataOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.RequestMapDataOperation
 
RequestMapDataOperation(String) - Constructor for class com.hazelcast.replicatedmap.impl.operation.RequestMapDataOperation
 
requestMigration(NioThread) - Method in interface com.hazelcast.internal.networking.nio.MigratablePipeline
Requests the MigratablePipeline to move to the new NioThread.
requestMigration(NioThread) - Method in class com.hazelcast.internal.networking.nio.NioPipeline
Migrates this pipeline to a different owner.
requestNewSession(RaftGroupId) - Method in class com.hazelcast.client.cp.internal.session.ClientProxySessionManager
 
requestNewSession(RaftGroupId) - Method in class com.hazelcast.cp.internal.session.AbstractProxySessionManager
Creates a new session on the Raft group
requestNewSession(RaftGroupId) - Method in class com.hazelcast.cp.internal.session.ProxySessionManagerService
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicLongAddAndGetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicLongAlterCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicLongApplyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicLongCompareAndSetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndAddCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndSetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicLongGetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicRefApplyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicRefCompareAndSetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicRefContainsCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicRefGetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicRefSetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheAddEntryListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheAddInvalidationListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheAddNearCacheInvalidationListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheAddPartitionLostListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheAssignAndGetUuidsCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheClearCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheContainsKeyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheCreateConfigCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheDestroyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheEntryProcessorCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheEventJournalReadCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheEventJournalSubscribeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheFetchNearCacheInvalidationMetadataCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheGetAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheGetAndRemoveCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheGetAndReplaceCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheGetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheGetConfigCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheIterateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheIterateEntriesCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheListenerRegistrationCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheLoadAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheManagementConfigCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CachePutAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CachePutCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CachePutIfAbsentCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllKeysCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheRemoveCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheRemoveEntryListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheRemoveInvalidationListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheRemovePartitionLostListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheReplaceCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheSetExpiryPolicyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheSizeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorAddCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorEstimateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientAddDistributedObjectListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientAddMembershipListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionLostListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientCreateProxiesCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientCreateProxyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientDeployClassesCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientDestroyProxyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientGetDistributedObjectsCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientGetPartitionsCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientIsFailoverSupportedCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientLocalBackupListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientPingCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientRemoveAllListenersCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientRemoveDistributedObjectListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientRemovePartitionLostListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientStatisticsCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ContinuousQueryAddListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ContinuousQueryDestroyCacheCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ContinuousQueryMadePublishableCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateWithValueCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ContinuousQuerySetReadCursorCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CountDownLatchAwaitCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CountDownLatchCountDownCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetCountCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetRoundCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CountDownLatchTrySetCountCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CPGroupCreateCPGroupCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CPGroupDestroyCPObjectCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CPSessionCloseSessionCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CPSessionCreateSessionCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CPSessionGenerateThreadIdCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CPSessionHeartbeatSessionCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DurableExecutorDisposeResultCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DurableExecutorIsShutdownCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveAndDisposeResultCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveResultCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DurableExecutorShutdownCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DurableExecutorSubmitToPartitionCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCardinalityEstimatorConfigCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddDurableExecutorConfigCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddExecutorConfigCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddFlakeIdGeneratorConfigCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddListConfigCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMultiMapConfigCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddPNCounterConfigCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddQueueConfigCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReliableTopicConfigCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReplicatedMapConfigCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddRingbufferConfigCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddScheduledExecutorConfigCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddSetConfigCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddTopicConfigCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnAddressCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnPartitionCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ExecutorServiceIsShutdownCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ExecutorServiceShutdownCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToAddressCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToPartitionCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.FencedLockGetLockOwnershipCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.FencedLockLockCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.FencedLockTryLockCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.FencedLockUnlockCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.FlakeIdGeneratorNewIdBatchCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListAddAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListAddAllWithIndexCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListAddCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListAddListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListAddWithIndexCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListClearCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListCompareAndRemoveAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListCompareAndRetainAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListContainsAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListContainsCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListGetAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListGetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListIndexOfCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListIsEmptyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListIteratorCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListLastIndexOfCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListListIteratorCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListRemoveCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListRemoveListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListRemoveWithIndexCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListSetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListSizeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListSubCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyWithPredicateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerWithPredicateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddIndexCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddInterceptorCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheEntryListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheInvalidationListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddPartitionLostListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAggregateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAggregateWithPredicateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAssignAndGetUuidsCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapClearCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapClearNearCacheCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapContainsKeyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapContainsValueCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapDeleteCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPagingPredicateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPredicateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapEntrySetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapEventJournalReadCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapEventJournalSubscribeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapEvictAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapEvictCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapExecuteOnAllKeysCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeysCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapExecuteWithPredicateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapFetchEntriesCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapFetchKeysCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapFetchNearCacheInvalidationMetadataCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapFetchWithQueryCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapFlushCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapForceUnlockCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapGetAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapGetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapGetEntryViewCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapIsEmptyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapIsLockedCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapKeySetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPagingPredicateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPredicateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapLoadAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapLoadGivenKeysCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapLockCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapProjectCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapProjectWithPredicateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapPutAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapPutCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentWithMaxIdleCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapPutTransientCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapPutTransientWithMaxIdleCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapPutWithMaxIdleCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapRemoveAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapRemoveCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapRemoveEntryListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapRemoveIfSameCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapRemoveInterceptorCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapRemovePartitionLostListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapReplaceCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapReplaceIfSameCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapSetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapSetTtlCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapSetWithMaxIdleCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapSizeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapSubmitToKeyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapTryLockCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapTryPutCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapTryRemoveCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapUnlockCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapValuesCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapValuesWithPagingPredicateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapValuesWithPredicateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MetricsReadMetricsCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerToKeyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapClearCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapContainsEntryCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapContainsKeyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapContainsValueCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapDeleteCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapEntrySetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapForceUnlockCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapGetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapIsLockedCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapKeySetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapLockCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapPutCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapSizeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapTryLockCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapUnlockCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapValueCountCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapValuesCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.PNCounterAddCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.PNCounterGetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.PNCounterGetConfiguredReplicaCountCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueAddAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueAddListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueClearCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRemoveAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRetainAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueContainsAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueContainsCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueDrainToCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueDrainToMaxSizeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueIsEmptyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueIteratorCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueOfferCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueuePeekCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueuePollCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueuePutCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueRemainingCapacityCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueRemoveCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueRemoveListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueSizeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueTakeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyWithPredicateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerWithPredicateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddNearCacheEntryListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapClearCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsKeyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsValueCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapEntrySetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapGetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapIsEmptyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapKeySetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveEntryListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapSizeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapValuesCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.RingbufferAddAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.RingbufferAddCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.RingbufferCapacityCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.RingbufferHeadSequenceCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.RingbufferReadManyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.RingbufferReadOneCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.RingbufferRemainingCapacityCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.RingbufferSizeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.RingbufferTailSequenceCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromAddressCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromPartitionCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromAddressCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromPartitionCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetAllScheduledFuturesCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromAddressCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromPartitionCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromAddressCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromPartitionCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromAddressCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromPartitionCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromAddressCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromPartitionCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromAddressCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromPartitionCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorShutdownCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToAddressCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToPartitionCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SemaphoreAcquireCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SemaphoreAvailablePermitsCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SemaphoreChangeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SemaphoreDrainCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SemaphoreGetSemaphoreTypeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SemaphoreInitCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SemaphoreReleaseCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetAddAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetAddCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetAddListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetClearCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetCompareAndRemoveAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetCompareAndRetainAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetContainsAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetContainsCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetGetAllCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetIsEmptyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetRemoveCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetRemoveListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetSizeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TopicAddMessageListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TopicPublishCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TopicRemoveMessageListenerCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalListAddCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalListRemoveCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalListSizeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsKeyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsValueCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapDeleteCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetForUpdateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapIsEmptyCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetWithPredicateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutIfAbsentCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveIfSameCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceIfSameCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapSetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapSizeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesWithPredicateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapGetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapPutCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveEntryCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapSizeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapValueCountCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalQueueOfferCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePeekCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePollCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalQueueSizeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalQueueTakeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalSetAddCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalSetRemoveCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalSetSizeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionCommitCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionCreateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionRollbackCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.XATransactionClearRemoteCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.XATransactionCollectTransactionsCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.XATransactionCommitCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.XATransactionCreateCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.XATransactionFinalizeCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.XATransactionPrepareCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.XATransactionRollbackCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.internal.longregister.client.codec.LongRegisterAddAndGetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.internal.longregister.client.codec.LongRegisterDecrementAndGetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndAddCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndIncrementCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndSetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.internal.longregister.client.codec.LongRegisterGetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.internal.longregister.client.codec.LongRegisterIncrementAndGetCodec.RequestParameters
 
RequestParameters() - Constructor for class com.hazelcast.internal.longregister.client.codec.LongRegisterSetCodec.RequestParameters
 
requiresAuthentication() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
requiresAuthentication() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
 
requiresAuthentication() - Method in class com.hazelcast.client.impl.protocol.task.IsFailoverSupportedMessageTask
 
requiresAuthentication() - Method in class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
 
requiresExplicitServiceName() - Method in class com.hazelcast.spi.impl.operationservice.Operation
Returns true to force the explicit service name serialization for this operation, false otherwise.
RequiresJdk8 - Annotation Type in com.hazelcast.internal
Annotates classes and methods which depend on JDK 8 API methods for compilation.
requiresPrepare() - Method in class com.hazelcast.transaction.impl.TransactionImpl
Checks if this Transaction needs to be prepared.
RES_100 - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
RES_200 - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
RES_200_WITH_NO_CONTENT - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
RES_204 - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
RES_400 - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
RES_403 - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
RES_404 - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
RES_500 - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
RES_503 - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
RESERVATION_ID - Static variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
reservationId - Variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
reserveAdd(UUID, Data) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
reserveAddBackup(long, UUID) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
RESERVED - Static variable in interface com.hazelcast.internal.nearcache.NearCacheRecord
 
ReserveForUpdateFunction(Data) - Constructor for class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore.ReserveForUpdateFunction
 
reserveRemove(long, Data, UUID) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
reserveRemoveBackup(long, UUID) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
reset() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
reset() - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
reset() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
 
reset() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Resets the record store to it's initial state.
reset() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorService
 
reset() - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
reset() - Method in class com.hazelcast.client.impl.protocol.ClientMessageReader
 
reset() - Method in class com.hazelcast.client.impl.proxy.ClientPNCounterProxy
 
reset() - Method in interface com.hazelcast.client.impl.spi.ClientClusterService
 
reset() - Method in interface com.hazelcast.client.impl.spi.ClientPartitionService
 
reset() - Method in class com.hazelcast.client.impl.spi.impl.ClientClusterServiceImpl
 
reset() - Method in class com.hazelcast.client.impl.spi.impl.ClientPartitionServiceImpl
 
reset() - Method in class com.hazelcast.collection.impl.collection.CollectionService
 
reset() - Method in class com.hazelcast.collection.impl.queue.QueueService
 
reset() - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueService
 
reset() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
reset() - Method in interface com.hazelcast.cp.internal.persistence.CPPersistenceService
Deletes all persisted data from the storage.
reset() - Method in class com.hazelcast.cp.internal.persistence.NopCPPersistenceService
 
reset() - Method in class com.hazelcast.cp.internal.raft.impl.state.QueryState
Resets the collection of waiting queries and acknowledged followers.
reset() - Method in class com.hazelcast.cp.internal.RaftService
 
reset() - Method in class com.hazelcast.cp.internal.session.ProxySessionManagerService
 
reset() - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
reset() - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Resets the observed state by this PN counter.
reset() - Method in class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
 
reset() - Method in class com.hazelcast.executor.impl.DistributedExecutorService
 
reset() - Method in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorService
 
reset() - Method in class com.hazelcast.instance.impl.Node
Resets the internal cluster-state of the Node to be able to make it ready to join a new cluster.
reset() - Method in interface com.hazelcast.internal.cluster.fd.ClusterFailureDetector
Clear all state kept by this failure detector
reset() - Method in class com.hazelcast.internal.cluster.fd.DeadlineClusterFailureDetector
 
reset() - Method in class com.hazelcast.internal.cluster.fd.PhiAccrualClusterFailureDetector
 
reset() - Method in class com.hazelcast.internal.cluster.fd.PingFailureDetector
 
reset() - Method in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
reset() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
reset() - Method in class com.hazelcast.internal.cluster.impl.MulticastJoiner
 
reset() - Method in interface com.hazelcast.internal.cluster.Joiner
 
reset() - Method in class com.hazelcast.internal.crdt.CRDTReplicationMigrationService
 
reset() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterProxy
 
reset() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterService
 
reset() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
reset() - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
reset() - Method in class com.hazelcast.internal.longregister.LongRegisterService
 
reset() - Method in class com.hazelcast.internal.metrics.impl.MetricsService
 
reset() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.BatchInvalidator
 
reset() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
Resets this invalidator back to its initial state.
reset() - Method in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
reset() - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnectionErrorHandler
 
reset(boolean) - Method in class com.hazelcast.internal.nio.tcp.TcpIpEndpointManager
 
reset(boolean) - Method in class com.hazelcast.internal.nio.UnifiedAggregateEndpointManager
 
reset() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
reset() - Method in class com.hazelcast.internal.serialization.impl.DataInputNavigableJsonAdapter
 
reset() - Method in class com.hazelcast.internal.serialization.impl.NavigableJsonInputAdapter
Resets the read cursor.
reset() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
reset() - Method in class com.hazelcast.internal.serialization.impl.StringNavigableJsonAdapter
 
reset() - Method in interface com.hazelcast.internal.services.ManagedService
Resets this service back to its initial state.
reset() - Method in class com.hazelcast.internal.usercodedeployment.UserCodeDeploymentService
 
reset() - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap.LongIterator
Makes this iterator reusable.
reset() - Method in interface com.hazelcast.internal.util.collection.LongCursor
Resets the cursor to the inital state.
reset() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotCursor
Resets the cursor to the initial state.
reset() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase.Cursor
 
reset() - Method in class com.hazelcast.internal.util.ItemCounter
Reset state of the counter to 0.
reset() - Method in interface com.hazelcast.map.impl.EntryCostEstimator
Reset the current estimation to zero.
reset() - Method in class com.hazelcast.map.impl.MapManagedService
 
reset() - Method in class com.hazelcast.map.impl.MapService
 
reset() - Method in interface com.hazelcast.map.impl.MapServiceContext
 
reset() - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
Returns all associated resources of this map-data-store back to the initial state.
reset() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
reset() - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
reset() - Method in class com.hazelcast.map.impl.nearcache.MapNearCacheManager
 
reset() - Method in interface com.hazelcast.map.impl.querycache.accumulator.Accumulator
Resets this accumulator.
reset() - Method in interface com.hazelcast.map.impl.querycache.accumulator.AccumulatorHandler
Resets this handler to its initial state.
reset() - Method in class com.hazelcast.map.impl.querycache.accumulator.BasicAccumulator
 
reset() - Method in interface com.hazelcast.map.impl.querycache.accumulator.CyclicBuffer
Resets this buffer; after the return of this method buffer will be empty and all elements in it will be null.
reset() - Method in class com.hazelcast.map.impl.querycache.accumulator.DefaultCyclicBuffer
 
reset() - Method in class com.hazelcast.map.impl.querycache.event.sequence.DefaultPartitionSequencer
 
reset(int) - Method in class com.hazelcast.map.impl.querycache.event.sequence.DefaultSubscriberSequencerProvider
 
reset() - Method in interface com.hazelcast.map.impl.querycache.event.sequence.PartitionSequencer
reset(int) - Method in interface com.hazelcast.map.impl.querycache.event.sequence.SubscriberSequencerProvider
Resets the sequence number for the supplied partition to zero.
reset() - Method in class com.hazelcast.map.impl.querycache.publisher.PublisherAccumulatorHandler
 
reset() - Method in class com.hazelcast.map.impl.querycache.subscriber.SubscriberAccumulator
 
reset() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
reset() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Resets the record store to it's initial state.
reset() - Method in class com.hazelcast.monitor.impl.LocalRecordStoreStatsImpl
 
reset() - Method in class com.hazelcast.monitor.impl.PartitionIndexOperationStats
Resets this stats instance to be ready for reuse.
reset() - Method in class com.hazelcast.multimap.impl.MultiMapService
 
reset() - Method in class com.hazelcast.query.impl.getters.JsonPathCursor
 
reset() - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
 
reset() - Method in interface com.hazelcast.query.PagingPredicate
Resets for reuse.
reset() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
reset() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
reset() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
reset() - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
reset() - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
reset() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
reset() - Method in class com.hazelcast.spi.impl.operationparker.impl.OperationParkerImpl
 
reset(Throwable) - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
 
reset() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
reset() - Method in class com.hazelcast.spi.impl.operationservice.impl.RaftInvocationContext
 
reset() - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicService
 
reset() - Method in class com.hazelcast.topic.impl.TopicService
 
reset() - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
reset() - Method in class com.hazelcast.transaction.impl.xa.XAService
 
reset() - Method in interface com.hazelcast.wan.WanReplicationPublisher
Resets the publisher (e.g.
RESET_PERIOD_SECONDS - Static variable in class com.hazelcast.internal.diagnostics.StoreLatencyPlugin
The period in second the statistics should be reset.
resetAccessHit() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
resetAccessHit() - Method in interface com.hazelcast.cache.impl.record.CacheRecord
Resets the access hit count of this Evictable to 0.
resetAccessHit() - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
resetAccessHit() - Method in interface com.hazelcast.internal.nearcache.NearCacheRecord
Resets the access hit count of this Evictable to 0.
resetAll() - Method in class com.hazelcast.map.impl.querycache.event.sequence.DefaultSubscriberSequencerProvider
 
resetAll() - Method in interface com.hazelcast.map.impl.querycache.event.sequence.SubscriberSequencerProvider
Like SubscriberSequencerProvider.reset(int) but this method resets all partition sequences.
resetCacheEntryListenerCount() - Method in class com.hazelcast.cache.impl.CacheContext
 
resetCacheManager() - Method in interface com.hazelcast.cache.impl.ICacheInternal
Reset cache manager of this cache proxy to null.
resetEntryCount() - Method in class com.hazelcast.cache.impl.CacheContext
 
resetFlagsTo(int) - Method in class com.hazelcast.internal.nio.Packet
Resets the entire flags bitfield to the supplied value.
resetGroupMembers() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Resets Raft group members back.
resetGroupMembers() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
resetInternalState() - Method in class com.hazelcast.cp.internal.session.AbstractProxySessionManager
 
resetInvalidationEvents() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
resetInvalidationListenerCount() - Method in class com.hazelcast.cache.impl.CacheContext
 
resetJoinState() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
resetMigrating() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionImpl
Resets migrating flag.
resetMigrationInterceptor() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
resetOverride() - Static method in class com.hazelcast.internal.util.RuntimeAvailableProcessors
Resets the overridden number of available processors to Runtime.availableProcessors().
resetPartitionMetaData(String, int) - Method in class com.hazelcast.cache.impl.CacheEventHandler
 
resetPartitionMetaData(String, int) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
 
resetPerQueryStats() - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
resetPerQueryStats() - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
resetPerQueryStats() - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Resets the per-query stats, if any, currently tracked by this internal index stats instance.
resetSearch() - Method in class com.hazelcast.client.impl.clientside.ClientDiscoveryService
 
resetSequence() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataContainer
 
resetSequence(String, int) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataGenerator
 
resetService(boolean) - Method in interface com.hazelcast.internal.hotrestart.InternalHotRestartService
Resets local service data, removes hot restart directories and recreates them.
resetService(boolean) - Method in class com.hazelcast.internal.hotrestart.NoopInternalHotRestartService
 
resetStaleSequence() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataContainer
 
resizeThreshold() - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
Get the actual threshold which when reached the map resize.
resizeThreshold() - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
Get the actual threshold which when reached the map resize.
resizeTo(long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
Allocates a new slot array with the requested size and moves all the assigned slots from the current array into the new one.
resolve(Object) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
resolve(ProtocolType, String) - Static method in class com.hazelcast.instance.EndpointQualifier
 
resolve(Object) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
resolve(Object) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
resolve(Object) - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationFuture
 
resolveAndThrowIfException(Object) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
resolveAndThrowIfException(Object) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
resolveAndThrowIfException(Object) - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationFuture
 
resolveAndThrowWithJoinConvention(Object) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
resolveClientConfig(ClientConfig) - Static method in class com.hazelcast.client.impl.clientside.FailoverClientConfigSupport
If clientConfig is null, the client configuration is loaded using the resolution logic as described in HazelcastClient.newHazelcastClient()

Used with HazelcastClient.newHazelcastClient() or HazelcastClient.newHazelcastClient(ClientConfig)

resolveClientFailoverConfig() - Static method in class com.hazelcast.client.impl.clientside.FailoverClientConfigSupport
Loads failover configuration using the search logic described in HazelcastClient.newHazelcastFailoverClient() and builds ClientFailoverConfig.
resolveClientFailoverConfig(ClientFailoverConfig) - Static method in class com.hazelcast.client.impl.clientside.FailoverClientConfigSupport
If clientFailoverConfig passed null, then loads failover configuration using the search logic described in HazelcastClient.newHazelcastFailoverClient() and builds ClientFailoverConfig.
resolveFuture(Future<Object>) - Static method in class com.hazelcast.internal.management.ManagementCenterService
 
resolveResponse(ClientMessage, boolean) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
resolveResponseForRecoveryOperation(Object) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientSubscriberContextSupport
 
resolveResponseForRecoveryOperation(Object) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeSubscriberContextSupport
 
resolveResponseForRecoveryOperation(Object) - Method in interface com.hazelcast.map.impl.querycache.subscriber.SubscriberContextSupport
Resolves response of recoveryOperation.
ResourceRegistry<W extends WaitKey,R extends BlockingResource<W>> - Class in com.hazelcast.cp.internal.datastructures.spi.blocking
Base class for registries for blocking resources.
ResourceRegistry() - Constructor for class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
ResourceRegistry(CPGroupId) - Constructor for class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
resources - Variable in class com.hazelcast.cache.impl.AbstractCacheService
Map from full prefixed cache name to set of Closeable resources
resources - Variable in class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
response - Variable in class com.hazelcast.cache.impl.operation.KeyBasedCacheOperation
 
response - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongAddAndGetCodec.ResponseParameters
the updated value, the given value added to the current value
response - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongAlterCodec.ResponseParameters
TODO DOC
response - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongApplyCodec.ResponseParameters
The result of the function application.
response - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongCompareAndSetCodec.ResponseParameters
true if successful; or false if the actual value was not equal to the expected value.
response - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndAddCodec.ResponseParameters
the old value before the add
response - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndSetCodec.ResponseParameters
the old value
response - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetCodec.ResponseParameters
The current value
response - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefApplyCodec.ResponseParameters
The result of the function application.
response - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefCompareAndSetCodec.ResponseParameters
true if successful; or false if the actual value was not equal to the expected value.
response - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefContainsCodec.ResponseParameters
true if the value is found, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefGetCodec.ResponseParameters
The current value
response - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefSetCodec.ResponseParameters
the old value or null, depending on the {
response - Variable in class com.hazelcast.client.impl.protocol.codec.CacheAddEntryListenerCodec.ResponseParameters
Registration id for the registered listener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.CacheAddInvalidationListenerCodec.ResponseParameters
Registration id for the registered listener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.CacheAddNearCacheInvalidationListenerCodec.ResponseParameters
Registration id for the registered listener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.CacheAddPartitionLostListenerCodec.ResponseParameters
returns the registration id for the CachePartitionLostListener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.CacheContainsKeyCodec.ResponseParameters
Returns true if cache value for the key exists, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.CacheCreateConfigCodec.ResponseParameters
The created configuration object.
response - Variable in class com.hazelcast.client.impl.protocol.codec.CacheEntryProcessorCodec.ResponseParameters
the result of the processing, if any, defined by the EntryProcessor implementation
response - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAllCodec.ResponseParameters
A map of entries that were found for the given keys.
response - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAndRemoveCodec.ResponseParameters
the value if one existed or null if no mapping existed for this key
response - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAndReplaceCodec.ResponseParameters
The old value previously assigned to the given key.
response - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetCodec.ResponseParameters
The value assigned to the given key, or null if not assigned.
response - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetConfigCodec.ResponseParameters
The cache configuration.
response - Variable in class com.hazelcast.client.impl.protocol.codec.CachePutCodec.ResponseParameters
The value previously assigned to the given key, or null if not assigned.
response - Variable in class com.hazelcast.client.impl.protocol.codec.CachePutIfAbsentCodec.ResponseParameters
true if a value was set, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveCodec.ResponseParameters
returns false if there was no matching key
response - Variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveEntryListenerCodec.ResponseParameters
true if the listener is de-registered, false otherwise
response - Variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveInvalidationListenerCodec.ResponseParameters
true if the listener is de-registered, false otherwise
response - Variable in class com.hazelcast.client.impl.protocol.codec.CacheRemovePartitionLostListenerCodec.ResponseParameters
true if registration is removed, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.CacheReplaceCodec.ResponseParameters
The replaced value.
response - Variable in class com.hazelcast.client.impl.protocol.codec.CacheSetExpiryPolicyCodec.ResponseParameters
{
response - Variable in class com.hazelcast.client.impl.protocol.codec.CacheSizeCodec.ResponseParameters
total entry count
response - Variable in class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorEstimateCodec.ResponseParameters
the previous cached estimation or the newly computed one.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAddDistributedObjectListenerCodec.ResponseParameters
The registration id for the distributed object listener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAddMembershipListenerCodec.ResponseParameters
Returns the registration id for the listener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionLostListenerCodec.ResponseParameters
The listener registration id.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ClientGetDistributedObjectsCodec.ResponseParameters
An array of distributed object info in the cluster.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ClientIsFailoverSupportedCodec.ResponseParameters
Returns true if server supports cluster failover
response - Variable in class com.hazelcast.client.impl.protocol.codec.ClientLocalBackupListenerCodec.ResponseParameters
Returns the registration id for the listener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ClientRemoveDistributedObjectListenerCodec.ResponseParameters
true if the listener existed and removed, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ClientRemovePartitionLostListenerCodec.ResponseParameters
true if the listener existed and removed, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryAddListenerCodec.ResponseParameters
Registration id for the listener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryDestroyCacheCodec.ResponseParameters
True if all cache is destroyed, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryMadePublishableCodec.ResponseParameters
True if successfully set as publishable, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateCodec.ResponseParameters
Array of keys.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateWithValueCodec.ResponseParameters
Array of key-value pairs.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQuerySetReadCursorCodec.ResponseParameters
True if the cursor position could be set, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchAwaitCodec.ResponseParameters
true if the count reached zero, false if the waiting time elapsed before the count reached 0
response - Variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetCountCodec.ResponseParameters
The current count of this CountDownLatch instance
response - Variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetRoundCodec.ResponseParameters
The current round of this CountDownLatch instance
response - Variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchTrySetCountCodec.ResponseParameters
true if the new count was set, false if the current count is not zero.
response - Variable in class com.hazelcast.client.impl.protocol.codec.CPSessionCloseSessionCodec.ResponseParameters
true if the session is found & closed, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.CPSessionGenerateThreadIdCodec.ResponseParameters
A unique ID for the caller thread
response - Variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorIsShutdownCodec.ResponseParameters
true if this executor has been shut down
response - Variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveAndDisposeResultCodec.ResponseParameters
The result of the callable execution with the given sequence.
response - Variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveResultCodec.ResponseParameters
The result of the callable execution with the given sequence.
response - Variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorSubmitToPartitionCodec.ResponseParameters
the sequence for the submitted execution.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnAddressCodec.ResponseParameters
True if cancelled successfully, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnPartitionCodec.ResponseParameters
True if cancelled successfully, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceIsShutdownCodec.ResponseParameters
true if this executor has been shut down
response - Variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToAddressCodec.ResponseParameters
The result of the callable execution.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToPartitionCodec.ResponseParameters
The result of the callable execution.
response - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockLockCodec.ResponseParameters
a valid fencing token (positive number) if the lock is acquired, otherwise -1.
response - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockTryLockCodec.ResponseParameters
a valid fencing token (positive number) if the lock is acquired, otherwise -1.
response - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockUnlockCodec.ResponseParameters
true if the lock is still held by the caller after a successful unlock() call, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListAddAllCodec.ResponseParameters
True if this list changed as a result of the call, false otherwise
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListAddAllWithIndexCodec.ResponseParameters
True if this list changed as a result of the call, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListAddCodec.ResponseParameters
true if this list changed as a result of the call, false otherwise
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListAddListenerCodec.ResponseParameters
Registration id for the listener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListCompareAndRemoveAllCodec.ResponseParameters
True if removed at least one of the items, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListCompareAndRetainAllCodec.ResponseParameters
True if this list changed as a result of the call, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListContainsAllCodec.ResponseParameters
True if this list contains all of the elements of the specified collection
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListContainsCodec.ResponseParameters
True if this list contains the specified element, false otherwise
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListGetAllCodec.ResponseParameters
An array of all item values in the list.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListGetCodec.ResponseParameters
The element at the specified position in this list
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListIndexOfCodec.ResponseParameters
The index of the first occurrence of the specified element in this list, or -1 if this list does not contain the element
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListIsEmptyCodec.ResponseParameters
True if this list contains no elements
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListIteratorCodec.ResponseParameters
An iterator over the elements in this list in proper sequence
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListLastIndexOfCodec.ResponseParameters
the index of the last occurrence of the specified element in this list, or -1 if this list does not contain the element
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListListIteratorCodec.ResponseParameters
a list iterator over the elements in this list (in proper sequence), starting at the specified position in the list
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListRemoveCodec.ResponseParameters
True if this list contained the specified element, false otherwise
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListRemoveListenerCodec.ResponseParameters
True if unregistered, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListRemoveWithIndexCodec.ResponseParameters
The element previously at the specified position
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListSetCodec.ResponseParameters
The element previously at the specified position
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListSizeCodec.ResponseParameters
The number of elements in this list
response - Variable in class com.hazelcast.client.impl.protocol.codec.ListSubCodec.ResponseParameters
A view of the specified range within this list
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerCodec.ResponseParameters
A unique string which is used as a key to remove the listener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyCodec.ResponseParameters
A unique string which is used as a key to remove the listener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyWithPredicateCodec.ResponseParameters
A unique string which is used as a key to remove the listener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerWithPredicateCodec.ResponseParameters
A unique string which is used as a key to remove the listener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddInterceptorCodec.ResponseParameters
id of registered interceptor.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheEntryListenerCodec.ResponseParameters
A unique string which is used as a key to remove the listener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheInvalidationListenerCodec.ResponseParameters
A unique string which is used as a key to remove the listener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapAddPartitionLostListenerCodec.ResponseParameters
returns the registration id for the MapPartitionLostListener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapAggregateCodec.ResponseParameters
the aggregation result
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapAggregateWithPredicateCodec.ResponseParameters
the aggregation result
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapContainsKeyCodec.ResponseParameters
Returns true if the key exists, otherwise returns false.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapContainsValueCodec.ResponseParameters
Returns true if the value exists, otherwise returns false.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPagingPredicateCodec.ResponseParameters
key-value pairs for the query.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPredicateCodec.ResponseParameters
result key-value entry collection of the query.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapEntrySetCodec.ResponseParameters
a set clone of the keys mappings in this map
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapEvictCodec.ResponseParameters
true if the key is evicted, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnAllKeysCodec.ResponseParameters
results of entry process on the entries
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeyCodec.ResponseParameters
result of entry process.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeysCodec.ResponseParameters
results of entry process on the entries with the provided keys
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteWithPredicateCodec.ResponseParameters
results of entry process on the entries matching the query criteria
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapGetAllCodec.ResponseParameters
values for the provided keys.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapGetCodec.ResponseParameters
The value for the key if exists
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapGetEntryViewCodec.ResponseParameters
TODO DOC
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapIsEmptyCodec.ResponseParameters
true if this map contains no key-value mappings
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapIsLockedCodec.ResponseParameters
Returns true if the entry is locked, otherwise returns false
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapKeySetCodec.ResponseParameters
a set clone of the keys contained in this map.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPagingPredicateCodec.ResponseParameters
result keys for the query.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPredicateCodec.ResponseParameters
result key set for the query.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapProjectCodec.ResponseParameters
the resulted collection upon transformation to the type of the projection
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapProjectWithPredicateCodec.ResponseParameters
the resulted collection upon transformation to the type of the projection
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutCodec.ResponseParameters
old value of the entry
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentCodec.ResponseParameters
returns a clone of the previous value, not the original (identically equal) value previously put into the map.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentWithMaxIdleCodec.ResponseParameters
old value of the entry
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutTransientWithMaxIdleCodec.ResponseParameters
old value of the entry
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutWithMaxIdleCodec.ResponseParameters
old value of the entry
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveCodec.ResponseParameters
Clone of the removed value, not the original (identically equal) value previously put into the map.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveEntryListenerCodec.ResponseParameters
true if registration is removed, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveIfSameCodec.ResponseParameters
Returns true if the key exists and removed, otherwise returns false.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveInterceptorCodec.ResponseParameters
Returns true if successful, otherwise returns false
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemovePartitionLostListenerCodec.ResponseParameters
true if registration is removed, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapReplaceCodec.ResponseParameters
Clone of the previous value, not the original (identically equal) value previously put into the map.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapReplaceIfSameCodec.ResponseParameters
true if value is replaced with new one, false otherwise
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapSetTtlCodec.ResponseParameters
'true' if the entry is affected, 'false' otherwise
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapSetWithMaxIdleCodec.ResponseParameters
old value of the entry
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapSizeCodec.ResponseParameters
the number of key-value mappings in this map
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapSubmitToKeyCodec.ResponseParameters
result of entry process.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapTryLockCodec.ResponseParameters
Returns true if successful, otherwise returns false
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapTryPutCodec.ResponseParameters
Returns true if successful, otherwise returns false
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapTryRemoveCodec.ResponseParameters
Returns true if successful, otherwise returns false
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapValuesCodec.ResponseParameters
All values in the map
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapValuesWithPagingPredicateCodec.ResponseParameters
values for the query.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MapValuesWithPredicateCodec.ResponseParameters
result value collection of the query.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerCodec.ResponseParameters
Returns registration id for the entry listener
response - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerToKeyCodec.ResponseParameters
Returns registration id for the entry listener
response - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsEntryCodec.ResponseParameters
True if the multimap contains the key-value pair, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsKeyCodec.ResponseParameters
True if the multimap contains an entry with the key, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsValueCodec.ResponseParameters
True if the multimap contains an entry with the value, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapEntrySetCodec.ResponseParameters
The set of key-value pairs in the multimap.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapGetCodec.ResponseParameters
The collection of the values associated with the key.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapIsLockedCodec.ResponseParameters
True if the lock acquired,false otherwise
response - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapKeySetCodec.ResponseParameters
The set of keys in the multimap.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapPutCodec.ResponseParameters
True if size of the multimap is increased, false if the multimap already contains the key-value pair.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveCodec.ResponseParameters
True if the size of the multimap changed after the remove operation, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryCodec.ResponseParameters
True if the size of the multimap changed after the remove operation, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryListenerCodec.ResponseParameters
True if registration is removed, false otherwise
response - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapSizeCodec.ResponseParameters
The number of key-value pairs in the multimap.
response - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapTryLockCodec.ResponseParameters
True if the lock was acquired and false if the waiting time elapsed before the lock acquired
response - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapValueCountCodec.ResponseParameters
The number of values that match the given key in the multimap
response - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapValuesCodec.ResponseParameters
The collection of values in the multimap.
response - Variable in class com.hazelcast.client.impl.protocol.codec.PNCounterGetConfiguredReplicaCountCodec.ResponseParameters
the configured replica count
response - Variable in class com.hazelcast.client.impl.protocol.codec.QueueAddAllCodec.ResponseParameters
true if this collection changed as a result of the call
response - Variable in class com.hazelcast.client.impl.protocol.codec.QueueAddListenerCodec.ResponseParameters
The registration id
response - Variable in class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRemoveAllCodec.ResponseParameters
true if this collection changed as a result of the call
response - Variable in class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRetainAllCodec.ResponseParameters
true if this collection changed as a result of the call
response - Variable in class com.hazelcast.client.impl.protocol.codec.QueueContainsAllCodec.ResponseParameters
true if this collection contains all of the elements in the specified collection
response - Variable in class com.hazelcast.client.impl.protocol.codec.QueueContainsCodec.ResponseParameters
true if this collection contains the specified element
response - Variable in class com.hazelcast.client.impl.protocol.codec.QueueDrainToCodec.ResponseParameters
list of all removed data in queue
response - Variable in class com.hazelcast.client.impl.protocol.codec.QueueDrainToMaxSizeCodec.ResponseParameters
list of all removed data in result of this method
response - Variable in class com.hazelcast.client.impl.protocol.codec.QueueIsEmptyCodec.ResponseParameters
True if this collection contains no elements
response - Variable in class com.hazelcast.client.impl.protocol.codec.QueueIteratorCodec.ResponseParameters
list of all data in queue
response - Variable in class com.hazelcast.client.impl.protocol.codec.QueueOfferCodec.ResponseParameters
True if the element was added to this queue, else false
response - Variable in class com.hazelcast.client.impl.protocol.codec.QueuePeekCodec.ResponseParameters
The head of this queue, or null if this queue is empty
response - Variable in class com.hazelcast.client.impl.protocol.codec.QueuePollCodec.ResponseParameters
The head of this queue, or null if this queue is empty
response - Variable in class com.hazelcast.client.impl.protocol.codec.QueueRemainingCapacityCodec.ResponseParameters
The remaining capacity
response - Variable in class com.hazelcast.client.impl.protocol.codec.QueueRemoveCodec.ResponseParameters
true if this queue changed as a result of the call
response - Variable in class com.hazelcast.client.impl.protocol.codec.QueueRemoveListenerCodec.ResponseParameters
True if the item listener is removed, false otherwise
response - Variable in class com.hazelcast.client.impl.protocol.codec.QueueSizeCodec.ResponseParameters
The number of elements in this collection
response - Variable in class com.hazelcast.client.impl.protocol.codec.QueueTakeCodec.ResponseParameters
The head of this queue
response - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerCodec.ResponseParameters
A unique string which is used as a key to remove the listener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyCodec.ResponseParameters
A unique string which is used as a key to remove the listener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyWithPredicateCodec.ResponseParameters
A unique string which is used as a key to remove the listener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerWithPredicateCodec.ResponseParameters
A unique string which is used as a key to remove the listener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddNearCacheEntryListenerCodec.ResponseParameters
A unique string which is used as a key to remove the listener.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsKeyCodec.ResponseParameters
True if this map contains a mapping for the specified key
response - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsValueCodec.ResponseParameters
true if this map maps one or more keys to the specified value
response - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapEntrySetCodec.ResponseParameters
A lazy set view of the mappings contained in this map.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapGetCodec.ResponseParameters
The value to which the specified key is mapped, or null if this map contains no mapping for the key
response - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapIsEmptyCodec.ResponseParameters
True if this map contains no key-value mappings
response - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapKeySetCodec.ResponseParameters
A lazy set view of the keys contained in this map.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutCodec.ResponseParameters
The old value if existed for the key.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveCodec.ResponseParameters
the previous value associated with key, or null if there was no mapping for key.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveEntryListenerCodec.ResponseParameters
True if registration is removed, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapSizeCodec.ResponseParameters
the number of key-value mappings in this map.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapValuesCodec.ResponseParameters
A collection view of the values contained in this map.
response - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferAddAllCodec.ResponseParameters
the ICompletableFuture to synchronize on completion.
response - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferAddCodec.ResponseParameters
the sequence of the added item, or -1 if the add failed.
response - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferCapacityCodec.ResponseParameters
the capacity
response - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferHeadSequenceCodec.ResponseParameters
the sequence of the head
response - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferReadOneCodec.ResponseParameters
the read item
response - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferRemainingCapacityCodec.ResponseParameters
the remaining capacity
response - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferSizeCodec.ResponseParameters
the size
response - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferTailSequenceCodec.ResponseParameters
the sequence of the tail
response - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromAddressCodec.ResponseParameters
True if the task was cancelled
response - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromPartitionCodec.ResponseParameters
True if the task was cancelled
response - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromAddressCodec.ResponseParameters
The remaining delay of the task formatted in nanoseconds.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromPartitionCodec.ResponseParameters
The remaining delay of the task formatted in nanoseconds.
response - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromAddressCodec.ResponseParameters
The result of the completed task, in serialized form ({
response - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromPartitionCodec.ResponseParameters
The result of the completed task, in serialized form ({
response - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromAddressCodec.ResponseParameters
True if the task is cancelled
response - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromPartitionCodec.ResponseParameters
True if the task is cancelled
response - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromAddressCodec.ResponseParameters
True if the task is done
response - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromPartitionCodec.ResponseParameters
True if the task is done
response - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreAcquireCodec.ResponseParameters
true if requested permits are acquired, false otherwise
response - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreAvailablePermitsCodec.ResponseParameters
number of available permits
response - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreChangeCodec.ResponseParameters
true
response - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreDrainCodec.ResponseParameters
number of acquired permits
response - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreGetSemaphoreTypeCodec.ResponseParameters
true if the semaphore is JDK compatible
response - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreInitCodec.ResponseParameters
true if the ISemaphore is initialized with this call
response - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreReleaseCodec.ResponseParameters
true
response - Variable in class com.hazelcast.client.impl.protocol.codec.SetAddAllCodec.ResponseParameters
True if this set changed as a result of the call
response - Variable in class com.hazelcast.client.impl.protocol.codec.SetAddCodec.ResponseParameters
True if this set did not already contain the specified element and the element is added, returns false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.SetAddListenerCodec.ResponseParameters
The registration id.
response - Variable in class com.hazelcast.client.impl.protocol.codec.SetCompareAndRemoveAllCodec.ResponseParameters
true if at least one item in values existed and removed, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.SetCompareAndRetainAllCodec.ResponseParameters
true if at least one item in values existed and it is retained, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.SetContainsAllCodec.ResponseParameters
true if this set contains all of the elements of the specified collection
response - Variable in class com.hazelcast.client.impl.protocol.codec.SetContainsCodec.ResponseParameters
True if this set contains the specified element, false otherwise
response - Variable in class com.hazelcast.client.impl.protocol.codec.SetGetAllCodec.ResponseParameters
Array of all values in the Set
response - Variable in class com.hazelcast.client.impl.protocol.codec.SetIsEmptyCodec.ResponseParameters
True if this set contains no elements
response - Variable in class com.hazelcast.client.impl.protocol.codec.SetRemoveCodec.ResponseParameters
True if this set contained the specified element and it is removed successfully
response - Variable in class com.hazelcast.client.impl.protocol.codec.SetRemoveListenerCodec.ResponseParameters
true if the listener with the provided id existed and removed, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.SetSizeCodec.ResponseParameters
The number of elements in this set (its cardinality)
response - Variable in class com.hazelcast.client.impl.protocol.codec.TopicAddMessageListenerCodec.ResponseParameters
returns the registration id
response - Variable in class com.hazelcast.client.impl.protocol.codec.TopicRemoveMessageListenerCodec.ResponseParameters
True if registration is removed, false otherwise
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListAddCodec.ResponseParameters
True if the item is added successfully, false otherwise
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListRemoveCodec.ResponseParameters
True if the removed successfully,false otherwise
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListSizeCodec.ResponseParameters
The size of the list
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsKeyCodec.ResponseParameters
True if this map contains an entry for the specified key.
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsValueCodec.ResponseParameters
True if this map contains an entry for the specified key.
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetCodec.ResponseParameters
The value for the specified key
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetForUpdateCodec.ResponseParameters
The value for the specified key
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapIsEmptyCodec.ResponseParameters
true if this map contains no entries.
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetCodec.ResponseParameters
A set clone of the keys contained in this map.
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetWithPredicateCodec.ResponseParameters
Result key set for the query.
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutCodec.ResponseParameters
Previous value associated with key or null if there was no mapping for key
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutIfAbsentCodec.ResponseParameters
The previous value associated with key, or null if there was no mapping for key.
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveCodec.ResponseParameters
The previous value associated with key, or null if there was no mapping for key
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveIfSameCodec.ResponseParameters
True if the value was removed
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceCodec.ResponseParameters
The previous value associated with key, or null if there was no mapping for key.
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceIfSameCodec.ResponseParameters
true if the value was replaced.
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSizeCodec.ResponseParameters
The number of entries in this map.
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesCodec.ResponseParameters
All values in the map
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesWithPredicateCodec.ResponseParameters
Result value collection of the query.
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapGetCodec.ResponseParameters
The collection of the values associated with the key
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapPutCodec.ResponseParameters
True if the size of the multimap is increased, false if the multimap already contains the key-value pair.
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveCodec.ResponseParameters
True if the size of the multimap changed after the remove operation, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveEntryCodec.ResponseParameters
True if the size of the multimap changed after the remove operation, false otherwise.
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapSizeCodec.ResponseParameters
The number of key-value pairs in the multimap
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapValueCountCodec.ResponseParameters
The number of values matching the given key in the multimap
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueOfferCodec.ResponseParameters
true if successful, or false if the specified waiting time elapses before space is available
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePeekCodec.ResponseParameters
The value at the head of the queue.
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePollCodec.ResponseParameters
The head of this queue, or null if the specified waiting time elapses before an element is available
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueSizeCodec.ResponseParameters
The number of elements in this collection
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueTakeCodec.ResponseParameters
The head of this queue
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetAddCodec.ResponseParameters
True if item is added successfully
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetRemoveCodec.ResponseParameters
True if item is remove successfully
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetSizeCodec.ResponseParameters
The size of the set
response - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionCreateCodec.ResponseParameters
The transaction id for the created transaction.
response - Variable in class com.hazelcast.client.impl.protocol.codec.XATransactionCollectTransactionsCodec.ResponseParameters
Array of Xids.
response - Variable in class com.hazelcast.client.impl.protocol.codec.XATransactionCreateCodec.ResponseParameters
The transaction unique identifier.
response - Variable in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
 
response - Variable in class com.hazelcast.collection.impl.queue.operations.QueueOperation
 
response - Variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
response(HttpPostCommandProcessor.ResponseType, Object...) - Static method in class com.hazelcast.internal.ascii.rest.HttpPostCommandProcessor
 
response - Variable in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
response - Variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterAddAndGetCodec.ResponseParameters
the updated value, the given value added to the current value
response - Variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterDecrementAndGetCodec.ResponseParameters
the updated value, the current value decremented by one
response - Variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndAddCodec.ResponseParameters
the old value before the add
response - Variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndIncrementCodec.ResponseParameters
the old value
response - Variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndSetCodec.ResponseParameters
the old value
response - Variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetCodec.ResponseParameters
the current value
response - Variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterIncrementAndGetCodec.ResponseParameters
The updated value, the current value incremented by one
response - Variable in class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
 
response - Variable in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
 
Response - Class in com.hazelcast.spi.impl.operationservice.impl.responses
A Response is a result of an Operation being executed.
Response() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.Response
 
Response(long, boolean) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.Response
 
RESPONSE_ALREADY_SENT - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
RESPONSE_BACKUP_ACKS_FIELD_OFFSET - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongAddAndGetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongAlterCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongApplyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongCompareAndSetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndAddCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndSetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongGetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefApplyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefCompareAndSetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefContainsCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefGetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefSetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheAddEntryListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheAddInvalidationListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheAddNearCacheInvalidationListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheAddPartitionLostListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheAssignAndGetUuidsCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheClearCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheContainsKeyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheCreateConfigCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheDestroyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheEntryProcessorCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalReadCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalSubscribeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheFetchNearCacheInvalidationMetadataCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAndRemoveCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAndReplaceCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheGetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheGetConfigCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheIterateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheIterateEntriesCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheListenerRegistrationCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheLoadAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheManagementConfigCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CachePutAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CachePutCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CachePutIfAbsentCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllKeysCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveEntryListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheRemoveInvalidationListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheRemovePartitionLostListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheReplaceCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheSetExpiryPolicyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CacheSizeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorAddCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorEstimateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientAddDistributedObjectListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientAddMembershipListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionLostListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientCreateProxiesCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientCreateProxyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientDeployClassesCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientDestroyProxyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientGetDistributedObjectsCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientGetPartitionsCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientIsFailoverSupportedCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientLocalBackupListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientPingCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientRemoveAllListenersCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientRemoveDistributedObjectListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientRemovePartitionLostListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ClientStatisticsCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryAddListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryDestroyCacheCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryMadePublishableCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateWithValueCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQuerySetReadCursorCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchAwaitCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchCountDownCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetCountCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetRoundCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchTrySetCountCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CPGroupCreateCPGroupCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CPGroupDestroyCPObjectCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CPSessionCloseSessionCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CPSessionCreateSessionCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CPSessionGenerateThreadIdCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.CPSessionHeartbeatSessionCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorDisposeResultCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorIsShutdownCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveAndDisposeResultCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveResultCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorShutdownCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorSubmitToPartitionCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCardinalityEstimatorConfigCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddDurableExecutorConfigCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddExecutorConfigCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddFlakeIdGeneratorConfigCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddListConfigCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMultiMapConfigCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddPNCounterConfigCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddQueueConfigCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReliableTopicConfigCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReplicatedMapConfigCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddRingbufferConfigCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddScheduledExecutorConfigCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddSetConfigCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddTopicConfigCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnAddressCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnPartitionCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceIsShutdownCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceShutdownCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToAddressCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToPartitionCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.FencedLockGetLockOwnershipCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.FencedLockLockCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.FencedLockTryLockCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.FencedLockUnlockCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.FlakeIdGeneratorNewIdBatchCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListAddAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListAddAllWithIndexCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListAddCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListAddListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListAddWithIndexCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListClearCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListCompareAndRemoveAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListCompareAndRetainAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListContainsAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListContainsCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListGetAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListGetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListIndexOfCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListIsEmptyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListIteratorCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListLastIndexOfCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListListIteratorCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListRemoveCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListRemoveListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListRemoveWithIndexCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListSetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListSizeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ListSubCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyWithPredicateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerWithPredicateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAddIndexCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAddInterceptorCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheEntryListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheInvalidationListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAddPartitionLostListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAggregateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAggregateWithPredicateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapAssignAndGetUuidsCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapClearCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapClearNearCacheCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapContainsKeyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapContainsValueCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapDeleteCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPagingPredicateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPredicateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapEntrySetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapEventJournalReadCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapEventJournalSubscribeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapEvictAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapEvictCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnAllKeysCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeysCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteWithPredicateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapFetchEntriesCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapFetchKeysCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapFetchNearCacheInvalidationMetadataCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapFetchWithQueryCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapFlushCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapForceUnlockCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapGetAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapGetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapGetEntryViewCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapIsEmptyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapIsLockedCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapKeySetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPagingPredicateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPredicateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapLoadAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapLoadGivenKeysCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapLockCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapProjectCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapProjectWithPredicateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapPutAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapPutCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentWithMaxIdleCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapPutTransientCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapPutTransientWithMaxIdleCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapPutWithMaxIdleCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveEntryListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveIfSameCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveInterceptorCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapRemovePartitionLostListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapReplaceCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapReplaceIfSameCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapSetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapSetTtlCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapSetWithMaxIdleCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapSizeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapSubmitToKeyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapTryLockCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapTryPutCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapTryRemoveCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapUnlockCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapValuesCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapValuesWithPagingPredicateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MapValuesWithPredicateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MetricsReadMetricsCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerToKeyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapClearCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsEntryCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsKeyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsValueCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapDeleteCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapEntrySetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapForceUnlockCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapGetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapIsLockedCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapKeySetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapLockCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapPutCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapSizeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapTryLockCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapUnlockCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapValueCountCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.MultiMapValuesCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.PNCounterAddCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.PNCounterGetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.PNCounterGetConfiguredReplicaCountCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueAddAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueAddListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueClearCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRemoveAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRetainAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueContainsAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueContainsCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueDrainToCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueDrainToMaxSizeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueIsEmptyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueIteratorCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueOfferCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueuePeekCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueuePollCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueuePutCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueRemainingCapacityCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueRemoveCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueRemoveListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueSizeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.QueueTakeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyWithPredicateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerWithPredicateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddNearCacheEntryListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapClearCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsKeyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsValueCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapEntrySetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapGetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapIsEmptyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapKeySetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveEntryListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapSizeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapValuesCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.RingbufferAddAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.RingbufferAddCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.RingbufferCapacityCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.RingbufferHeadSequenceCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.RingbufferReadManyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.RingbufferReadOneCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.RingbufferRemainingCapacityCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.RingbufferSizeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.RingbufferTailSequenceCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromAddressCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromPartitionCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromAddressCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromPartitionCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetAllScheduledFuturesCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromAddressCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromPartitionCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromAddressCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromPartitionCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromAddressCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromPartitionCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromAddressCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromPartitionCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromAddressCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromPartitionCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorShutdownCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToAddressCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToPartitionCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreAcquireCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreAvailablePermitsCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreChangeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreDrainCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreGetSemaphoreTypeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreInitCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreReleaseCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetAddAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetAddCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetAddListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetClearCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetCompareAndRemoveAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetCompareAndRetainAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetContainsAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetContainsCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetGetAllCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetIsEmptyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetRemoveCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetRemoveListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.SetSizeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TopicAddMessageListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TopicPublishCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TopicRemoveMessageListenerCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListAddCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListRemoveCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListSizeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsKeyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsValueCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapDeleteCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetForUpdateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapIsEmptyCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetWithPredicateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutIfAbsentCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveIfSameCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceIfSameCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSizeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesWithPredicateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapGetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapPutCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveEntryCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapSizeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapValueCountCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueOfferCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePeekCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePollCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueSizeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueTakeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetAddCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetRemoveCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetSizeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionCommitCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionCreateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.TransactionRollbackCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.XATransactionClearRemoteCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.XATransactionCollectTransactionsCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.XATransactionCommitCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.XATransactionCreateCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.XATransactionFinalizeCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.XATransactionPrepareCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.client.impl.protocol.codec.XATransactionRollbackCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterAddAndGetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterDecrementAndGetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndAddCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndIncrementCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndSetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterGetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterIncrementAndGetCodec
 
RESPONSE_MESSAGE_TYPE - Static variable in class com.hazelcast.internal.longregister.client.codec.LongRegisterSetCodec
 
RESPONSE_SIZE_IN_BYTES - Static variable in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
 
RESPONSE_THREAD_COUNT - Static variable in class com.hazelcast.client.properties.ClientProperty
The number of response threads.
RESPONSE_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
The number of threads that process responses.
RESPONSE_THREAD_DYNAMIC - Static variable in class com.hazelcast.client.properties.ClientProperty
Enabled dynamic switching between processing responses on the io threads and offloading the response threads.
ResponseAlreadySentException - Exception in com.hazelcast.spi.exception
A HazelcastException indicating that there is some kind of system error causing a response to be send multiple times for some operation.
ResponseAlreadySentException() - Constructor for exception com.hazelcast.spi.exception.ResponseAlreadySentException
 
ResponseAlreadySentException(String) - Constructor for exception com.hazelcast.spi.exception.ResponseAlreadySentException
 
responseOnSetLicenseSuccess() - Method in class com.hazelcast.internal.ascii.rest.HttpPostCommandProcessor
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicLongAddAndGetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicLongAlterCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicLongApplyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicLongCompareAndSetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndAddCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicLongGetAndSetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicLongGetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicRefApplyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicRefCompareAndSetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicRefContainsCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicRefGetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.AtomicRefSetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheAddEntryListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheAddInvalidationListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheAddNearCacheInvalidationListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheAddPartitionLostListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheAssignAndGetUuidsCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheClearCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheContainsKeyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheCreateConfigCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheDestroyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheEntryProcessorCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheEventJournalReadCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheEventJournalSubscribeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheFetchNearCacheInvalidationMetadataCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheGetAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheGetAndRemoveCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheGetAndReplaceCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheGetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheGetConfigCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheIterateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheIterateEntriesCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheListenerRegistrationCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheLoadAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheManagementConfigCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CachePutAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CachePutCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CachePutIfAbsentCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheRemoveAllKeysCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheRemoveCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheRemoveEntryListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheRemoveInvalidationListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheRemovePartitionLostListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheReplaceCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheSetExpiryPolicyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CacheSizeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorAddCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CardinalityEstimatorEstimateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientAddDistributedObjectListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientAddMembershipListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientAddPartitionLostListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientCreateProxiesCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientCreateProxyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientDeployClassesCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientDestroyProxyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientGetDistributedObjectsCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientGetPartitionsCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientIsFailoverSupportedCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientLocalBackupListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientPingCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientRemoveAllListenersCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientRemoveDistributedObjectListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientRemovePartitionLostListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ClientStatisticsCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ContinuousQueryAddListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ContinuousQueryDestroyCacheCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ContinuousQueryMadePublishableCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ContinuousQueryPublisherCreateWithValueCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ContinuousQuerySetReadCursorCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CountDownLatchAwaitCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CountDownLatchCountDownCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetCountCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CountDownLatchGetRoundCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CountDownLatchTrySetCountCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CPGroupCreateCPGroupCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CPGroupDestroyCPObjectCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CPSessionCloseSessionCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CPSessionCreateSessionCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CPSessionGenerateThreadIdCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.CPSessionHeartbeatSessionCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DurableExecutorDisposeResultCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DurableExecutorIsShutdownCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveAndDisposeResultCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveResultCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DurableExecutorShutdownCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DurableExecutorSubmitToPartitionCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCardinalityEstimatorConfigCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddDurableExecutorConfigCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddExecutorConfigCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddFlakeIdGeneratorConfigCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddListConfigCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMultiMapConfigCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddPNCounterConfigCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddQueueConfigCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReliableTopicConfigCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReplicatedMapConfigCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddRingbufferConfigCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddScheduledExecutorConfigCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddSetConfigCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddTopicConfigCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnAddressCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnPartitionCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ExecutorServiceIsShutdownCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ExecutorServiceShutdownCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToAddressCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToPartitionCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.FencedLockGetLockOwnershipCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.FencedLockLockCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.FencedLockTryLockCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.FencedLockUnlockCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.FlakeIdGeneratorNewIdBatchCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListAddAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListAddAllWithIndexCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListAddCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListAddListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListAddWithIndexCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListClearCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListCompareAndRemoveAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListCompareAndRetainAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListContainsAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListContainsCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListGetAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListGetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListIndexOfCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListIsEmptyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListIteratorCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListLastIndexOfCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListListIteratorCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListRemoveCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListRemoveListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListRemoveWithIndexCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListSetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListSizeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ListSubCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerToKeyWithPredicateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddEntryListenerWithPredicateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddIndexCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddInterceptorCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheEntryListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddNearCacheInvalidationListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAddPartitionLostListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAggregateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAggregateWithPredicateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapAssignAndGetUuidsCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapClearCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapClearNearCacheCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapContainsKeyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapContainsValueCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapDeleteCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPagingPredicateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapEntriesWithPredicateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapEntrySetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapEventJournalReadCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapEventJournalSubscribeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapEvictAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapEvictCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapExecuteOnAllKeysCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeysCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapExecuteWithPredicateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapFetchEntriesCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapFetchKeysCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapFetchNearCacheInvalidationMetadataCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapFetchWithQueryCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapFlushCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapForceUnlockCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapGetAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapGetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapGetEntryViewCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapIsEmptyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapIsLockedCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapKeySetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPagingPredicateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapKeySetWithPredicateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapLoadAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapLoadGivenKeysCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapLockCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapProjectCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapProjectWithPredicateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapPutAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapPutCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentWithMaxIdleCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapPutTransientCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapPutTransientWithMaxIdleCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapPutWithMaxIdleCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapRemoveAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapRemoveCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapRemoveEntryListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapRemoveIfSameCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapRemoveInterceptorCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapRemovePartitionLostListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapReplaceCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapReplaceIfSameCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapSetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapSetTtlCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapSetWithMaxIdleCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapSizeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapSubmitToKeyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapTryLockCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapTryPutCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapTryRemoveCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapUnlockCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapValuesCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapValuesWithPagingPredicateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MapValuesWithPredicateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MetricsReadMetricsCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapAddEntryListenerToKeyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapClearCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapContainsEntryCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapContainsKeyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapContainsValueCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapDeleteCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapEntrySetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapForceUnlockCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapGetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapIsLockedCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapKeySetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapLockCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapPutCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapSizeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapTryLockCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapUnlockCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapValueCountCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.MultiMapValuesCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.PNCounterAddCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.PNCounterGetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.PNCounterGetConfiguredReplicaCountCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueAddAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueAddListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueClearCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRemoveAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueCompareAndRetainAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueContainsAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueContainsCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueDrainToCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueDrainToMaxSizeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueIsEmptyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueIteratorCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueOfferCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueuePeekCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueuePollCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueuePutCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueRemainingCapacityCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueRemoveCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueRemoveListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueSizeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.QueueTakeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerToKeyWithPredicateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddEntryListenerWithPredicateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapAddNearCacheEntryListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapClearCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsKeyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsValueCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapEntrySetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapGetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapIsEmptyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapKeySetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapRemoveEntryListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapSizeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ReplicatedMapValuesCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.RingbufferAddAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.RingbufferAddCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.RingbufferCapacityCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.RingbufferHeadSequenceCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.RingbufferReadManyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.RingbufferReadOneCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.RingbufferRemainingCapacityCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.RingbufferSizeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.RingbufferTailSequenceCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromAddressCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromPartitionCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromAddressCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromPartitionCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetAllScheduledFuturesCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromAddressCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromPartitionCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromAddressCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromPartitionCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromAddressCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromPartitionCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromAddressCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromPartitionCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromAddressCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromPartitionCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorShutdownCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToAddressCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToPartitionCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SemaphoreAcquireCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SemaphoreAvailablePermitsCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SemaphoreChangeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SemaphoreDrainCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SemaphoreGetSemaphoreTypeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SemaphoreInitCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SemaphoreReleaseCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetAddAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetAddCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetAddListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetClearCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetCompareAndRemoveAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetCompareAndRetainAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetContainsAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetContainsCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetGetAllCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetIsEmptyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetRemoveCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetRemoveListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.SetSizeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TopicAddMessageListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TopicPublishCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TopicRemoveMessageListenerCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalListAddCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalListRemoveCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalListSizeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsKeyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsValueCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapDeleteCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetForUpdateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapIsEmptyCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetWithPredicateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutIfAbsentCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveIfSameCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceIfSameCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapSetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapSizeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesWithPredicateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapGetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapPutCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveEntryCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapSizeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapValueCountCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalQueueOfferCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePeekCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePollCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalQueueSizeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalQueueTakeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalSetAddCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalSetRemoveCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionalSetSizeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionCommitCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionCreateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.TransactionRollbackCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.XATransactionClearRemoteCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.XATransactionCollectTransactionsCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.XATransactionCommitCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.XATransactionCreateCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.XATransactionFinalizeCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.XATransactionPrepareCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.client.impl.protocol.codec.XATransactionRollbackCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.internal.longregister.client.codec.LongRegisterAddAndGetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.internal.longregister.client.codec.LongRegisterDecrementAndGetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndAddCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndIncrementCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.internal.longregister.client.codec.LongRegisterGetAndSetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.internal.longregister.client.codec.LongRegisterGetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.internal.longregister.client.codec.LongRegisterIncrementAndGetCodec.ResponseParameters
 
ResponseParameters() - Constructor for class com.hazelcast.internal.longregister.client.codec.LongRegisterSetCodec.ResponseParameters
 
responseQueueSize - Variable in class com.hazelcast.internal.management.dto.OperationServiceDTO
 
responseQueueSize() - Method in class com.hazelcast.spi.impl.operationservice.impl.InboundResponseHandlerSupplier
 
responses - Variable in class com.hazelcast.map.impl.operation.MultipleEntryOperation
 
responses - Variable in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
 
REST - Static variable in class com.hazelcast.instance.EndpointQualifier
 
REST - Static variable in class com.hazelcast.internal.nio.Protocols
Protocol that is used by REST
REST_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Deprecated.
REST_VALUE - Static variable in class com.hazelcast.internal.ascii.TextProtocolsDataSerializerHook
 
RestApiConfig - Class in com.hazelcast.config
This class allows to control which parts of Hazelcast REST API will be enabled.
RestApiConfig() - Constructor for class com.hazelcast.config.RestApiConfig
 
RestApiFilter - Class in com.hazelcast.internal.nio.ascii
This class is a policy enforcement point for HTTP REST API.
RestApiTextDecoder - Class in com.hazelcast.internal.nio.ascii
 
RestApiTextDecoder(TcpIpConnection, TextEncoder, boolean) - Constructor for class com.hazelcast.internal.nio.ascii.RestApiTextDecoder
 
restart() - Method in interface com.hazelcast.cp.CPSubsystemManagementService
Wipes and resets the whole CP Subsystem state and initializes it as if the Hazelcast cluster is starting up initially.
restart() - Method in class com.hazelcast.cp.internal.RaftService
 
restart() - Method in interface com.hazelcast.internal.networking.Networking
Restarts Networking.
restart() - Method in class com.hazelcast.internal.networking.nio.NioNetworking
 
RESTART_CP_MEMBER_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
RestartCPMemberOp - Class in com.hazelcast.cp.internal.operation
Resets CP state of a member and restarts CP Subsystem initialization process
RestartCPMemberOp() - Constructor for class com.hazelcast.cp.internal.operation.RestartCPMemberOp
 
RestartCPMemberOp(long) - Constructor for class com.hazelcast.cp.internal.operation.RestartCPMemberOp
 
RestartingMemberIterator - Class in com.hazelcast.internal.util.iterator
Iterates over stable cluster from the oldest to youngest member.
RestartingMemberIterator(ClusterService, int) - Constructor for class com.hazelcast.internal.util.iterator.RestartingMemberIterator
 
restartLocal(long) - Method in class com.hazelcast.cp.internal.RaftService
 
RestEndpointGroup - Enum in com.hazelcast.config
Enum of REST endpoint groups.
RESTORE_SNAPSHOT_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
RestoredRaftState - Class in com.hazelcast.cp.internal.raft.impl.persistence
Contains persisted and restored state of a RaftNode.
RestoredRaftState(RaftEndpoint, Collection<RaftEndpoint>, int, RaftEndpoint, SnapshotEntry, LogEntry[]) - Constructor for class com.hazelcast.cp.internal.raft.impl.persistence.RestoredRaftState
 
restoreGroupMembers(long, Collection<RaftEndpoint>) - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Restores group members from the snapshot.
restoreLocalCPMember(CPMemberInfo) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
restoreMetadataGroupId(RaftGroupId) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
restoreRaftLog(int, SnapshotEntry, LogEntry[]) - Static method in class com.hazelcast.cp.internal.raft.impl.log.RaftLog
 
restoreRaftLog(int, SnapshotEntry, LogEntry[], RaftStateStore) - Static method in class com.hazelcast.cp.internal.raft.impl.log.RaftLog
 
restoreRaftNode(CPGroupId, RestoredRaftState, RaftAlgorithmConfig, RaftIntegration) - Static method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Creates a new Raft node with restored Raft state
restoreRaftNode(CPGroupId, RestoredRaftState, RaftAlgorithmConfig, RaftIntegration, RaftStateStore) - Static method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Creates a new Raft node with restored Raft state and a RaftStateStore to persist Raft state changes
restoreRaftNode(RaftGroupId, RestoredRaftState, LogFileStructure) - Method in class com.hazelcast.cp.internal.RaftService
 
restoreRaftState(CPGroupId, RestoredRaftState, int) - Static method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
 
restoreRaftState(CPGroupId, RestoredRaftState, int, RaftStateStore) - Static method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
 
restoreSnapshot(CPGroupId, long, S) - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueService
 
restoreSnapshot(CPGroupId, long, RR) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
restoreSnapshot(CPGroupId, long, MetadataRaftGroupSnapshot) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
restoreSnapshot(Object, long) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Restores the snapshot with the given operation for the given commit index
restoreSnapshot(CPGroupId, long, T) - Method in interface com.hazelcast.cp.internal.raft.SnapshotAwareService
Restores the snapshot for specified CPGroupId.
restoreSnapshot(CPGroupId, long, MetadataRaftGroupSnapshot) - Method in class com.hazelcast.cp.internal.RaftService
 
restoreSnapshot(CPGroupId, long, RaftSessionRegistry) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
RestoreSnapshotOp - Class in com.hazelcast.cp.internal.raftop.snapshot
RaftOp to restore snapshot using related SnapshotAwareService.takeSnapshot(CPGroupId, long).
RestoreSnapshotOp() - Constructor for class com.hazelcast.cp.internal.raftop.snapshot.RestoreSnapshotOp
 
RestoreSnapshotOp(String, Object) - Constructor for class com.hazelcast.cp.internal.raftop.snapshot.RestoreSnapshotOp
 
RestServerEndpointConfig - Class in com.hazelcast.config
Server socket endpoint config specialized for REST service Allows configuring access to REST groups similar to RestApiConfig
RestServerEndpointConfig() - Constructor for class com.hazelcast.config.RestServerEndpointConfig
 
RestValue - Class in com.hazelcast.internal.ascii.rest
 
RestValue() - Constructor for class com.hazelcast.internal.ascii.rest.RestValue
 
RestValue(byte[], byte[]) - Constructor for class com.hazelcast.internal.ascii.rest.RestValue
 
result - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
result - Variable in class com.hazelcast.map.impl.iterator.AbstractMapPartitionIterator
 
Result<T extends Result> - Interface in com.hazelcast.map.impl.query
Result of a Query.
result - Variable in class com.hazelcast.scheduledexecutor.impl.operations.SyncStateOperation
 
RESULT_SEGMENT - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
resultDeserialized - Variable in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
 
ResultProcessor<T extends Result> - Interface in com.hazelcast.map.impl.query
Responsible for creating query results of a concrete type depending on the type of the Query.
resultProcessorRegistry - Variable in class com.hazelcast.map.impl.query.QueryRunner
 
ResultProcessorRegistry - Class in com.hazelcast.map.impl.query
Holds a registry of ResultProcessors for Result type.
ResultProcessorRegistry() - Constructor for class com.hazelcast.map.impl.query.ResultProcessorRegistry
 
ResultReadyNotifyOperation<V> - Class in com.hazelcast.scheduledexecutor.impl.operations
 
ResultReadyNotifyOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.ResultReadyNotifyOperation
 
ResultReadyNotifyOperation(ScheduledTaskHandler) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.ResultReadyNotifyOperation
 
results - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchWithQueryCodec.ResponseParameters
TODO DOC
results() - Method in class com.hazelcast.core.Pipelining
Returns the results.
ResultSegment - Class in com.hazelcast.map.impl.query
Represents a partial query result on a segment of the map.
ResultSegment() - Constructor for class com.hazelcast.map.impl.query.ResultSegment
 
ResultSegment(Result, int) - Constructor for class com.hazelcast.map.impl.query.ResultSegment
 
resultSet - Variable in class com.hazelcast.internal.journal.EventJournalReadOperation
 
ResultSet - Class in com.hazelcast.internal.util
A result set of Map.Entry objects that can be iterated according to IterationType
ResultSet(List<Map.Entry>, IterationType) - Constructor for class com.hazelcast.internal.util.ResultSet
 
ResultSet() - Constructor for class com.hazelcast.internal.util.ResultSet
 
resume() - Method in class com.hazelcast.transaction.impl.SuspendedTransaction
 
resume(String, String) - Method in interface com.hazelcast.wan.impl.WanReplicationService
Resumes WAN replication for the given wanReplicationName and wanPublisherId on this hazelcast instance.
resume(String, String) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
 
resume() - Method in interface com.hazelcast.wan.WanReplicationPublisher
This method re-enables WAN event containers polling for a paused or stopped WanReplicationPublisher instance.
resumeMigration() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
resumeMigration() - Method in interface com.hazelcast.internal.partition.InternalPartitionService
Resume all migrations
resumeTransaction() - Method in class com.hazelcast.client.impl.proxy.txn.TransactionContextProxy
 
resumeTransaction() - Method in class com.hazelcast.client.impl.proxy.txn.xa.XATransactionContextProxy
 
resumeTransaction() - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
 
resumeTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Resume suspended transaction.
retainAll(Collection<?>) - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
retainAll(Collection<?>) - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
retainAll(Collection<?>) - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
retainAll(Collection<?>) - Method in class com.hazelcast.client.impl.proxy.ClientSetProxy
 
retainAll(Collection<?>) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
retainAll(Collection<?>) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
retainAll(Collection<?>) - Method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
 
retainAll(Collection<?>) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationQueue
 
retainAll(Collection<?>) - Method in class com.hazelcast.internal.util.collection.ImmutableInflatableSet
 
retainAll(Collection<?>) - Method in class com.hazelcast.internal.util.collection.IntHashSet
 
retainAll(Collection<?>) - Method in class com.hazelcast.internal.util.collection.LongHashSet
 
retainAll(Collection<?>) - Method in class com.hazelcast.internal.util.collection.OAHashSet
 
retainAll(Collection<?>) - Method in class com.hazelcast.internal.util.ResultSet
 
retainAll(Collection<?>) - Method in class com.hazelcast.map.impl.query.QueryResultCollection
 
retainAll(Collection<?>) - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
 
retainNamespaces(int, Set<ServiceNamespace>) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
 
rethrow(Throwable) - Static method in class com.hazelcast.internal.util.ExceptionUtil
 
rethrow(Throwable, ExceptionUtil.RuntimeExceptionFactory) - Static method in class com.hazelcast.internal.util.ExceptionUtil
 
rethrow(Throwable, Class<T>) - Static method in class com.hazelcast.internal.util.ExceptionUtil
 
RETHROW_ALL_EXCEPT_MEMBER_LEFT - Static variable in class com.hazelcast.internal.util.FutureUtil
This ExceptionHandler rethrows ExecutionExceptions and logs MemberLeftExceptions to the log.
RETHROW_EVERYTHING - Static variable in class com.hazelcast.internal.util.FutureUtil
Just rethrows all exceptions
RETHROW_EXECUTION_EXCEPTION - Static variable in class com.hazelcast.internal.util.FutureUtil
This ExceptionHandler rethrows ExecutionExceptions and logs MemberLeftExceptions to the log.
RETHROW_TRANSACTION_EXCEPTION - Static variable in class com.hazelcast.internal.util.FutureUtil
Handler for transaction specific rethrown of exceptions.
rethrowAllowedTypeFirst(Throwable, Class<T>) - Static method in class com.hazelcast.internal.util.ExceptionUtil
This rethrow the exception providing an allowed Exception in first priority, even it is a Runtime exception
rethrowAllowInterrupted(Throwable) - Static method in class com.hazelcast.internal.util.ExceptionUtil
 
rethrowIfError(Throwable) - Static method in class com.hazelcast.internal.util.ExceptionUtil
 
retries() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKeyContainer
 
retrieve(int) - Method in class com.hazelcast.durableexecutor.impl.TaskRingBuffer
Gets the response
RETRIEVE_DISPOSE_RESULT - Static variable in class com.hazelcast.durableexecutor.impl.DurableExecutorDataSerializerHook
 
RETRIEVE_RESULT - Static variable in class com.hazelcast.durableexecutor.impl.DurableExecutorDataSerializerHook
 
retrieveAndDisposeResult(long) - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
retrieveAndDisposeResult(long) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Retrieves and disposes the result with the given taskId
retrieveAndDisposeResult(int) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorContainer
 
retrieveAndDisposeResult(long) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
RetrieveAndDisposeResultOperation - Class in com.hazelcast.durableexecutor.impl.operations
 
RetrieveAndDisposeResultOperation() - Constructor for class com.hazelcast.durableexecutor.impl.operations.RetrieveAndDisposeResultOperation
 
RetrieveAndDisposeResultOperation(String, int) - Constructor for class com.hazelcast.durableexecutor.impl.operations.RetrieveAndDisposeResultOperation
 
retrieveEncryptionKeys() - Method in interface com.hazelcast.spi.impl.securestore.SecureStore
Returns a list of encryption keys, where the first item represents the current active key and the other items represent previous keys (used for decryption of old chunks).
retrieveInitialSequence() - Method in class com.hazelcast.topic.impl.reliable.ReliableMessageListenerAdapter
 
retrieveInitialSequence() - Method in interface com.hazelcast.topic.ReliableMessageListener
Retrieves the initial sequence from which this ReliableMessageListener should start.
retrieveResult(long) - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
retrieveResult(long) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Retrieves the result with the given taskId
retrieveResult(int) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorContainer
 
retrieveResult(long) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
RetrieveResultOperation - Class in com.hazelcast.durableexecutor.impl.operations
Used to retrieve the response of an execution with the given sequence
RetrieveResultOperation() - Constructor for class com.hazelcast.durableexecutor.impl.operations.RetrieveResultOperation
 
RetrieveResultOperation(String, int) - Constructor for class com.hazelcast.durableexecutor.impl.operations.RetrieveResultOperation
 
RETRYABLE_HAZELCAST - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
RETRYABLE_IO - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
RetryableException - Interface in com.hazelcast.spi.exception
Marker interface for exceptions to indicate that an operation can be retried.
RetryableHazelcastException - Exception in com.hazelcast.spi.exception
A 'marker' exception that indicates that an operation can be retried.
RetryableHazelcastException() - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
 
RetryableHazelcastException(String) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
 
RetryableHazelcastException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
 
RetryableHazelcastException(Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
 
RetryableIOException - Exception in com.hazelcast.spi.exception
A IOException indicating that there was a IO failure, but it can be retried.
RetryableIOException() - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
 
RetryableIOException(String) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
 
RetryableIOException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
 
RetryableIOException(Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
 
retryCount() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKeyContainer
 
RETURN - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
 
RETURN_END - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
 
returnInputBuffer(BufferObjectDataInput) - Method in interface com.hazelcast.internal.serialization.impl.bufferpool.BufferPool
Returns a BufferObjectDataInput back to the pool.
returnInputBuffer(BufferObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolImpl
 
returnOldValue - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefSetCodec.RequestParameters
Denotes whether the old value is returned or not
returnOrThrowWithGetConventions(Object) - Static method in class com.hazelcast.spi.impl.operationservice.impl.InvocationFuture
 
returnOrThrowWithJoinConventions(Object) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
returnOutputBuffer(BufferObjectDataOutput) - Method in interface com.hazelcast.internal.serialization.impl.bufferpool.BufferPool
Returns a BufferObjectDataOutput back to the pool.
returnOutputBuffer(BufferObjectDataOutput) - Method in class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolImpl
 
returnsResponse() - Method in class com.hazelcast.cache.impl.operation.CacheClearExpiredOperation
 
returnsResponse() - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
Deprecated.
 
returnsResponse() - Method in class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
 
returnsResponse() - Method in class com.hazelcast.cp.internal.operation.integration.AsyncRaftOp
 
returnsResponse() - Method in class com.hazelcast.cp.internal.operation.RaftQueryOp
 
returnsResponse() - Method in class com.hazelcast.cp.internal.operation.RaftReplicateOp
 
returnsResponse() - Method in class com.hazelcast.cp.internal.raftop.metadata.CreateRaftNodeOp
 
returnsResponse() - Method in class com.hazelcast.cp.internal.raftop.metadata.DestroyRaftNodesOp
 
returnsResponse() - Method in class com.hazelcast.cp.internal.raftop.metadata.PublishActiveCPMembersOp
 
returnsResponse() - Method in class com.hazelcast.cp.internal.raftop.metadata.RaftServicePreJoinOp
 
returnsResponse() - Method in class com.hazelcast.internal.cluster.impl.operations.FetchMembersViewOp
 
returnsResponse() - Method in class com.hazelcast.internal.cluster.impl.operations.MembersUpdateOp
 
returnsResponse() - Method in class com.hazelcast.internal.cluster.impl.operations.MergeClustersOp
 
returnsResponse() - Method in class com.hazelcast.internal.cluster.impl.operations.PromoteLiteMemberOp
 
returnsResponse() - Method in class com.hazelcast.internal.metrics.managementcenter.ReadMetricsOperation
 
returnsResponse() - Method in class com.hazelcast.internal.partition.operation.FinalizeMigrationOperation
 
returnsResponse() - Method in class com.hazelcast.internal.partition.operation.PartitionBackupReplicaAntiEntropyOperation
 
returnsResponse() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRequest
 
returnsResponse() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncResponse
 
returnsResponse() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRetryResponse
 
returnsResponse() - Method in class com.hazelcast.internal.partition.operation.PartitionStateOperation
 
returnsResponse() - Method in class com.hazelcast.internal.partition.operation.ShutdownRequestOperation
 
returnsResponse() - Method in class com.hazelcast.internal.partition.operation.ShutdownResponseOperation
 
returnsResponse() - Method in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
 
returnsResponse() - Method in class com.hazelcast.map.impl.operation.EntryOperation
 
returnsResponse() - Method in class com.hazelcast.map.impl.operation.IsKeyLoadFinishedOperation
 
returnsResponse() - Method in class com.hazelcast.map.impl.operation.IsPartitionLoadedOperation
 
returnsResponse() - Method in class com.hazelcast.map.impl.operation.MapClearExpiredOperation
 
returnsResponse() - Method in class com.hazelcast.map.impl.operation.TriggerLoadIfNeededOperation
 
returnsResponse() - Method in class com.hazelcast.map.impl.querycache.accumulator.ConsumeAccumulatorOperation
 
returnsResponse() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.ReadAndResetAccumulatorOperation
 
returnsResponse() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.OnJoinRegistrationOperation
 
returnsResponse() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
 
returnsResponse() - Method in class com.hazelcast.spi.impl.operationservice.Operation
Method is intended to be overridden.
returnsResponse() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionBackupOperation
 
returnsResponse() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionBackupOperation
 
returnsResponse() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
 
returnsResponse() - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionBackupOperation
 
returnValueType - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongAlterCodec.RequestParameters
0 returns the old value, 1 returns the new value
returnValueType - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefApplyCodec.RequestParameters
0 returns no value, 1 returns the old value, 2 returns the new value
returnWithDeadline(Collection<Future<V>>, long, TimeUnit) - Static method in class com.hazelcast.internal.util.FutureUtil
 
returnWithDeadline(Collection<Future<V>>, long, TimeUnit, FutureUtil.ExceptionHandler) - Static method in class com.hazelcast.internal.util.FutureUtil
 
returnWithDeadline(Collection<Future<V>>, long, TimeUnit, long, TimeUnit) - Static method in class com.hazelcast.internal.util.FutureUtil
 
returnWithDeadline(Collection<Future<V>>, long, TimeUnit, long, TimeUnit, FutureUtil.ExceptionHandler) - Static method in class com.hazelcast.internal.util.FutureUtil
 
reversed() - Method in interface com.hazelcast.internal.util.function.ComparatorEx
Serializable variant of java.util.Comparator#reversed()
reverseOrder() - Static method in interface com.hazelcast.internal.util.function.ComparatorEx
Serializable variant of java.util.Comparator#reverseOrder().
REVISION - Static variable in class com.hazelcast.instance.GeneratedBuildProperties
 
RIMBeanServerDelegate(MBeanServerDelegate) - Constructor for class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
 
Ringbuffer<E> - Interface in com.hazelcast.ringbuffer.impl
The Ringbuffer is responsible for storing the actual content of a ringbuffer.
Ringbuffer<E> - Interface in com.hazelcast.ringbuffer
A Ringbuffer is a data structure where the content is stored in a ring-like structure.
ringbuffer - Variable in class com.hazelcast.topic.impl.reliable.MessageRunner
 
RINGBUFFER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
RINGBUFFER_CONTAINER - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
 
RINGBUFFER_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
RINGBUFFER_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
RINGBUFFER_MERGING_ENTRY - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
RINGBUFFER_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
RINGBUFFER_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
RINGBUFFER_STORE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
RingbufferAddAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds all the items of a collection to the tail of the Ringbuffer.
RingbufferAddAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
RingbufferAddAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
RingbufferAddAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.ringbuffer
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.RingbufferMessageType#RINGBUFFER_ADDALL
RingbufferAddAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddAllMessageTask
 
RingbufferAddCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds an item to the tail of the Ringbuffer.
RingbufferAddCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
RingbufferAddCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
RingbufferAddMessageTask - Class in com.hazelcast.client.impl.protocol.task.ringbuffer
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.RingbufferMessageType#RINGBUFFER_ADD
RingbufferAddMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddMessageTask
 
RingbufferCacheEventJournalImpl - Class in com.hazelcast.cache.impl.journal
The cache event journal implementation based on the Ringbuffer.
RingbufferCacheEventJournalImpl(NodeEngine) - Constructor for class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
 
RingbufferCapacityCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the capacity of this Ringbuffer.
RingbufferCapacityCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
RingbufferCapacityCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
RingbufferCapacityMessageTask - Class in com.hazelcast.client.impl.protocol.task.ringbuffer
 
RingbufferCapacityMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferCapacityMessageTask
 
RingbufferConfig - Class in com.hazelcast.config
Contains the configuration for the Ringbuffer.
RingbufferConfig() - Constructor for class com.hazelcast.config.RingbufferConfig
 
RingbufferConfig(String) - Constructor for class com.hazelcast.config.RingbufferConfig
Creates a RingbufferConfig with the provided name.
RingbufferConfig(RingbufferConfig) - Constructor for class com.hazelcast.config.RingbufferConfig
Clones a RingbufferConfig
RingbufferConfig(String, RingbufferConfig) - Constructor for class com.hazelcast.config.RingbufferConfig
Creates a new RingbufferConfig by cloning an existing config and overriding the name.
RingbufferConfigReadOnly - Class in com.hazelcast.internal.config
 
RingbufferConfigReadOnly(RingbufferConfig) - Constructor for class com.hazelcast.internal.config.RingbufferConfigReadOnly
 
RingbufferContainer<T,E> - Class in com.hazelcast.ringbuffer.impl
The RingbufferContainer is responsible for the functionalities supporting the underlying ringbuffer structure containing the data.
RingbufferContainer() - Constructor for class com.hazelcast.ringbuffer.impl.RingbufferContainer
For purposes of IdentifiedDataSerializable instance creation.
RingbufferContainer(ObjectNamespace, int) - Constructor for class com.hazelcast.ringbuffer.impl.RingbufferContainer
Constructs the ring buffer container with only the name and the key for blocking operations.
RingbufferContainer(ObjectNamespace, RingbufferConfig, NodeEngine, int) - Constructor for class com.hazelcast.ringbuffer.impl.RingbufferContainer
Constructs a fully initialized ringbuffer that can be used immediately.
RingbufferDataSerializerHook - Class in com.hazelcast.ringbuffer.impl
The DataSerializerHook for the Ringbuffer.
RingbufferDataSerializerHook() - Constructor for class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
 
RingbufferHeadSequenceCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the sequence of the head.
RingbufferHeadSequenceCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
RingbufferHeadSequenceCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
RingbufferHeadSequenceMessageTask - Class in com.hazelcast.client.impl.protocol.task.ringbuffer
 
RingbufferHeadSequenceMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferHeadSequenceMessageTask
 
RingbufferMapEventJournalImpl - Class in com.hazelcast.map.impl.journal
The map event journal implementation based on the Ringbuffer.
RingbufferMapEventJournalImpl(NodeEngine, MapServiceContext) - Constructor for class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
 
RingbufferMergeData - Class in com.hazelcast.spi.merge
A ringbuffer implementation holding data involved in split-brain healing.
RingbufferMergeData(int) - Constructor for class com.hazelcast.spi.merge.RingbufferMergeData
 
RingbufferMergeData(Ringbuffer<Object>) - Constructor for class com.hazelcast.spi.merge.RingbufferMergeData
 
RingbufferMergeDataReadOnlyIterator<E> - Class in com.hazelcast.spi.merge
Read-only iterator over items in a provided RingbufferMergeData.
RingbufferMergingValueImpl - Class in com.hazelcast.spi.impl.merge
RingbufferMergingValueImpl() - Constructor for class com.hazelcast.spi.impl.merge.RingbufferMergingValueImpl
 
RingbufferMergingValueImpl(SerializationService) - Constructor for class com.hazelcast.spi.impl.merge.RingbufferMergingValueImpl
 
RingBufferPermission - Class in com.hazelcast.security.permission
 
RingBufferPermission(String, String...) - Constructor for class com.hazelcast.security.permission.RingBufferPermission
 
RingbufferPortableHook - Class in com.hazelcast.ringbuffer.impl.client
Provides a Portable hook for the ringbuffer operations.
RingbufferPortableHook() - Constructor for class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
 
RingbufferProxy<E> - Class in com.hazelcast.ringbuffer.impl
The serverside proxy to access a Ringbuffer.
RingbufferProxy(NodeEngine, RingbufferService, String, RingbufferConfig) - Constructor for class com.hazelcast.ringbuffer.impl.RingbufferProxy
 
RingbufferReadManyCodec - Class in com.hazelcast.client.impl.protocol.codec
Reads a batch of items from the Ringbuffer.
RingbufferReadManyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
RingbufferReadManyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
RingbufferReadManyMessageTask - Class in com.hazelcast.client.impl.protocol.task.ringbuffer
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.RingbufferMessageType#RINGBUFFER_READMANY
RingbufferReadManyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadManyMessageTask
 
RingbufferReadOneCodec - Class in com.hazelcast.client.impl.protocol.codec
Reads one item from the Ringbuffer.
RingbufferReadOneCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
RingbufferReadOneCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
RingbufferReadOneMessageTask - Class in com.hazelcast.client.impl.protocol.task.ringbuffer
Client Protocol Task for handling messages with type ID: com.hazelcast.client.impl.protocol.codec.RingbufferMessageType#RINGBUFFER_READONE
RingbufferReadOneMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadOneMessageTask
 
RingbufferRemainingCapacityCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the remaining capacity of the ringbuffer.
RingbufferRemainingCapacityCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
RingbufferRemainingCapacityCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
RingbufferRemainingCapacityMessageTask - Class in com.hazelcast.client.impl.protocol.task.ringbuffer
 
RingbufferRemainingCapacityMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferRemainingCapacityMessageTask
 
RingbufferService - Class in com.hazelcast.ringbuffer.impl
The SPI Service that deals with the Ringbuffer.
RingbufferService(NodeEngineImpl) - Constructor for class com.hazelcast.ringbuffer.impl.RingbufferService
 
RingbufferSizeCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns number of items in the ringbuffer.
RingbufferSizeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
RingbufferSizeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
RingbufferSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.ringbuffer
 
RingbufferSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferSizeMessageTask
 
RingbufferStore<T> - Interface in com.hazelcast.ringbuffer
Ringbuffer store makes a ring buffer backed by a central data store; such as database, disk, etc.
ringbufferStoreConfig - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddRingbufferConfigCodec.RequestParameters
backing ringbuffer store configuration
RingbufferStoreConfig - Class in com.hazelcast.config
Configuration for the RingbufferStore.
RingbufferStoreConfig() - Constructor for class com.hazelcast.config.RingbufferStoreConfig
 
RingbufferStoreConfig(RingbufferStoreConfig) - Constructor for class com.hazelcast.config.RingbufferStoreConfig
 
RingbufferStoreConfigHolder - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
Adapter for using RingbufferStoreConfig in client protocol.
RingbufferStoreConfigHolder(String, String, Data, Data, Map<String, String>, boolean) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.RingbufferStoreConfigHolder
 
RingbufferStoreConfigHolderCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
RingbufferStoreConfigReadOnly - Class in com.hazelcast.internal.config
 
RingbufferStoreConfigReadOnly(RingbufferStoreConfig) - Constructor for class com.hazelcast.internal.config.RingbufferStoreConfigReadOnly
 
RingbufferStoreFactory<T> - Interface in com.hazelcast.ringbuffer
Creates a new RingbufferStore.
RingbufferStoreWrapper - Class in com.hazelcast.ringbuffer.impl
Wrapper for the ring buffer store.
RingbufferTailSequenceCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the sequence of the tail.
RingbufferTailSequenceCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
RingbufferTailSequenceCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
RingbufferTailSequenceMessageTask - Class in com.hazelcast.client.impl.protocol.task.ringbuffer
 
RingbufferTailSequenceMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferTailSequenceMessageTask
 
RingbufferWaitNotifyKey - Class in com.hazelcast.ringbuffer.impl
A AbstractWaitNotifyKey to make it possible to wait for an item to be published in the ringbuffer.
RingbufferWaitNotifyKey(ObjectNamespace, int) - Constructor for class com.hazelcast.ringbuffer.impl.RingbufferWaitNotifyKey
 
role() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns role of this node in the group.
rollback(Xid) - Method in class com.hazelcast.client.impl.proxy.txn.xa.XAResourceProxy
 
rollback() - Method in class com.hazelcast.transaction.impl.SuspendedTransaction
 
rollback() - Method in interface com.hazelcast.transaction.impl.Transaction
 
rollback() - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
rollback(NodeEngine) - Method in class com.hazelcast.transaction.impl.TransactionLog
 
rollback(Xid) - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
 
rollback() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
 
ROLLBACK_ALLOWED_DURING_PASSIVE_STATE_TX_BACKUP_LOG - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
ROLLBACK_CLUSTER_STATE - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
ROLLBACK_TX_BACKUP_LOG - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
rollbackAdd(long) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
rollbackAddBackup(long) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
RollbackAllowedDuringPassiveStateTxBackupLogOperation - Class in com.hazelcast.transaction.impl.operations
 
RollbackAllowedDuringPassiveStateTxBackupLogOperation() - Constructor for class com.hazelcast.transaction.impl.operations.RollbackAllowedDuringPassiveStateTxBackupLogOperation
 
RollbackAllowedDuringPassiveStateTxBackupLogOperation(UUID) - Constructor for class com.hazelcast.transaction.impl.operations.RollbackAllowedDuringPassiveStateTxBackupLogOperation
 
rollbackAsync(NodeEngine, BiConsumer) - Method in class com.hazelcast.transaction.impl.TransactionLog
 
rollbackAsync(BiConsumer) - Method in class com.hazelcast.transaction.impl.xa.XATransaction
 
rollbackBackupLog(UUID) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
rollbackClusterState(UUID) - Method in class com.hazelcast.internal.cluster.impl.ClusterStateManager
 
RollbackClusterStateOp - Class in com.hazelcast.internal.cluster.impl.operations
 
RollbackClusterStateOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.RollbackClusterStateOp
 
RollbackClusterStateOp(Address, UUID) - Constructor for class com.hazelcast.internal.cluster.impl.operations.RollbackClusterStateOp
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cache.impl.CacheService
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorService
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.collection.impl.collection.CollectionService
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cp.internal.datastructures.spi.AbstractCPMigrationAwareService
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cp.internal.RaftService
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.internal.longregister.LongRegisterService
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.map.impl.MapService
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.spi.impl.CountingMigrationAwareService
 
rollbackMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.partition.MigrationAwareService
Rollback the migration process for this service, on both source and destination members.
rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.transaction.impl.xa.XAService
 
rollbackRemove(long) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
rollbackRemove(long) - Method in class com.hazelcast.collection.impl.list.ListContainer
 
rollbackRemoveBackup(long) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
rollbackTransaction() - Method in class com.hazelcast.client.impl.proxy.txn.TransactionContextProxy
 
rollbackTransaction() - Method in class com.hazelcast.client.impl.proxy.txn.xa.XATransactionContextProxy
 
rollbackTransaction(UUID) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
rollbackTransaction(UUID) - Method in class com.hazelcast.collection.impl.collection.CollectionService
 
rollbackTransaction(UUID) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
 
rollbackTransaction(UUID) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
rollbackTransaction(UUID) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
rollbackTransaction(UUID) - Method in interface com.hazelcast.internal.services.TransactionalService
 
rollbackTransaction(UUID) - Method in class com.hazelcast.map.impl.MapService
 
rollbackTransaction(UUID) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
rollbackTransaction() - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
 
rollbackTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Rollback of the current transaction.
RollbackTxBackupLogOperation - Class in com.hazelcast.transaction.impl.operations
 
RollbackTxBackupLogOperation() - Constructor for class com.hazelcast.transaction.impl.operations.RollbackTxBackupLogOperation
 
RollbackTxBackupLogOperation(UUID) - Constructor for class com.hazelcast.transaction.impl.operations.RollbackTxBackupLogOperation
 
roundCapacity(long) - Static method in class com.hazelcast.internal.util.hashslot.impl.CapacityUtil
Round the capacity to the next allowed value.
roundCapacity(int) - Static method in class com.hazelcast.internal.util.hashslot.impl.CapacityUtil
Round the capacity to the next allowed value.
RoundRobinLB - Class in com.hazelcast.client.util
A LoadBalancer implementation that relies on using round robin to a next member to send a request to.
RoundRobinLB() - Constructor for class com.hazelcast.client.util.RoundRobinLB
 
RoundRobinLB(int) - Constructor for class com.hazelcast.client.util.RoundRobinLB
 
RUBY - Static variable in class com.hazelcast.client.impl.ClientTypes
RUBY client protocol ID
RuleBasedQueryOptimizer - Class in com.hazelcast.query.impl.predicates
Rule based optimizer.
RuleBasedQueryOptimizer() - Constructor for class com.hazelcast.query.impl.predicates.RuleBasedQueryOptimizer
 
run() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalSubscribeOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.AddCacheConfigOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheClearExpiredOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheContainsKeyOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
Deprecated.
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheDestroyOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheEntryIteratorOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheExpireBatchBackupOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheGetOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheKeyIteratorOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CachePutBackupOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheSetExpiryPolicyBackupOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheSetExpiryPolicyOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperation
 
run() - Method in class com.hazelcast.cache.impl.operation.OnJoinCacheOperation
 
run() - Method in class com.hazelcast.cardinality.impl.operations.AggregateBackupOperation
 
run() - Method in class com.hazelcast.cardinality.impl.operations.AggregateOperation
 
run() - Method in class com.hazelcast.cardinality.impl.operations.EstimateOperation
 
run() - Method in class com.hazelcast.cardinality.impl.operations.MergeBackupOperation
 
run() - Method in class com.hazelcast.cardinality.impl.operations.MergeOperation
 
run() - Method in class com.hazelcast.cardinality.impl.operations.ReplicationOperation
 
run() - Method in class com.hazelcast.client.impl.ClientHeartbeatMonitor
 
run() - Method in class com.hazelcast.client.impl.ClientLifecycleMonitor
 
run() - Method in class com.hazelcast.client.impl.connection.nio.HeartbeatManager
 
run() - Method in class com.hazelcast.client.impl.operations.GetConnectedClientsOperation
 
run() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
run() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsOperation
 
run() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsOperation
 
run() - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocation
 
run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
 
run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
 
run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionClearBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionClearOperation
 
run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionCompareAndRemoveOperation
 
run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionContainsOperation
 
run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionGetAllOperation
 
run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionIsEmptyOperation
 
run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionMergeBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionMergeOperation
 
run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveOperation
 
run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionReplicationOperation
 
run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionSizeOperation
 
run(List<Operation>) - Static method in class com.hazelcast.collection.impl.CollectionTxnUtil
 
run() - Method in class com.hazelcast.collection.impl.list.operations.ListAddAllOperation
 
run() - Method in class com.hazelcast.collection.impl.list.operations.ListAddOperation
 
run() - Method in class com.hazelcast.collection.impl.list.operations.ListGetOperation
 
run() - Method in class com.hazelcast.collection.impl.list.operations.ListIndexOfOperation
 
run() - Method in class com.hazelcast.collection.impl.list.operations.ListRemoveOperation
 
run() - Method in class com.hazelcast.collection.impl.list.operations.ListSetBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.list.operations.ListSetOperation
 
run() - Method in class com.hazelcast.collection.impl.list.operations.ListSubOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.AddAllBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.AddAllOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.CheckAndEvictOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.ClearBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.ClearOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.ContainsOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.DrainBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.DrainOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.IsEmptyOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.IteratorOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.OfferBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.PeekOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.PollBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.QueueMergeBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.QueueMergeOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.QueueReplicationOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.RemainingCapacityOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveOperation
 
run() - Method in class com.hazelcast.collection.impl.queue.operations.SizeOperation
 
run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitOperation
 
run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareOperation
 
run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveAddOperation
 
run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveRemoveOperation
 
run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackOperation
 
run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTransactionRollbackOperation
 
run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
 
run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
 
run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.QueueTransactionRollbackOperation
 
run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitOperation
 
run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
 
run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPeekOperation
 
run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollOperation
 
run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareOperation
 
run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferOperation
Runs the operation.
run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollOperation
 
run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackBackupOperation
 
run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackOperation
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.AddAndGetOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.AlterOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.ApplyOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.CompareAndSetOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.GetAndAddOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.GetAndSetOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.LocalGetOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.ApplyOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.CompareAndSetOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.ContainsOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.GetOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.SetOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.AwaitOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.CountDownOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.GetCountOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.GetRoundOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.TrySetCountOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.GetLockOwnershipStateOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.LockOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.TryLockOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.UnlockOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.AcquirePermitsOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.AvailablePermitsOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.ChangePermitsOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.DrainPermitsOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.InitSemaphoreOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.ReleasePermitsOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.operation.ExpireWaitKeysOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.spi.operation.DestroyRaftObjectOp
 
run() - Method in class com.hazelcast.cp.internal.operation.GetLeadedGroupsOp
 
run() - Method in class com.hazelcast.cp.internal.operation.integration.AppendFailureResponseOp
 
run() - Method in class com.hazelcast.cp.internal.operation.integration.AppendRequestOp
 
run() - Method in class com.hazelcast.cp.internal.operation.integration.AppendSuccessResponseOp
 
run() - Method in class com.hazelcast.cp.internal.operation.integration.InstallSnapshotOp
 
run() - Method in class com.hazelcast.cp.internal.operation.integration.PreVoteRequestOp
 
run() - Method in class com.hazelcast.cp.internal.operation.integration.PreVoteResponseOp
 
run() - Method in class com.hazelcast.cp.internal.operation.integration.TriggerLeaderElectionOp
 
run() - Method in class com.hazelcast.cp.internal.operation.integration.VoteRequestOp
 
run() - Method in class com.hazelcast.cp.internal.operation.integration.VoteResponseOp
 
run() - Method in class com.hazelcast.cp.internal.operation.RaftQueryOp
 
run() - Method in class com.hazelcast.cp.internal.operation.RaftReplicateOp
 
run() - Method in class com.hazelcast.cp.internal.operation.unsafe.UnsafeSnapshotReplicationOp
 
run() - Method in class com.hazelcast.cp.internal.operation.unsafe.UnsafeStateReplicationOp
 
run() - Method in class com.hazelcast.cp.internal.raft.impl.task.InitLeadershipTransferTask
 
run() - Method in class com.hazelcast.cp.internal.raft.impl.task.LeadershipTransferTask
 
run() - Method in class com.hazelcast.cp.internal.raft.impl.task.MembershipChangeTask
 
run() - Method in class com.hazelcast.cp.internal.raft.impl.task.QueryTask
 
run() - Method in class com.hazelcast.cp.internal.raft.impl.task.RaftNodeStatusAwareTask
 
run() - Method in class com.hazelcast.cp.internal.raft.impl.task.ReplicateTask
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.raftop.GetInitialRaftGroupMembersIfCurrentGroupMemberOp
 
run(MetadataRaftGroupManager, long) - Method in class com.hazelcast.cp.internal.raftop.metadata.AddCPMemberOp
 
run(MetadataRaftGroupManager, long) - Method in class com.hazelcast.cp.internal.raftop.metadata.CompleteDestroyRaftGroupsOp
 
run(MetadataRaftGroupManager, long) - Method in class com.hazelcast.cp.internal.raftop.metadata.CompleteRaftGroupMembershipChangesOp
 
run(MetadataRaftGroupManager, long) - Method in class com.hazelcast.cp.internal.raftop.metadata.CreateRaftGroupOp
 
run() - Method in class com.hazelcast.cp.internal.raftop.metadata.CreateRaftNodeOp
 
run() - Method in class com.hazelcast.cp.internal.raftop.metadata.DestroyRaftNodesOp
 
run(MetadataRaftGroupManager, long) - Method in class com.hazelcast.cp.internal.raftop.metadata.ForceDestroyRaftGroupOp
 
run(MetadataRaftGroupManager, long) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetActiveCPMembersOp
 
run(MetadataRaftGroupManager, long) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetActiveRaftGroupByNameOp
 
run(MetadataRaftGroupManager, long) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetActiveRaftGroupIdsOp
 
run(MetadataRaftGroupManager, long) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetDestroyingRaftGroupIdsOp
 
run(MetadataRaftGroupManager, long) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetMembershipChangeScheduleOp
 
run(MetadataRaftGroupManager, long) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetRaftGroupIdsOp
 
run(MetadataRaftGroupManager, long) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetRaftGroupOp
 
run(MetadataRaftGroupManager, long) - Method in class com.hazelcast.cp.internal.raftop.metadata.InitMetadataRaftGroupOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.raftop.metadata.MetadataRaftGroupOp
 
run(MetadataRaftGroupManager, long) - Method in class com.hazelcast.cp.internal.raftop.metadata.MetadataRaftGroupOp
 
run() - Method in class com.hazelcast.cp.internal.raftop.metadata.PublishActiveCPMembersOp
 
run() - Method in class com.hazelcast.cp.internal.raftop.metadata.RaftServicePreJoinOp
 
run(MetadataRaftGroupManager, long) - Method in class com.hazelcast.cp.internal.raftop.metadata.RemoveCPMemberOp
 
run(MetadataRaftGroupManager, long) - Method in class com.hazelcast.cp.internal.raftop.metadata.TriggerDestroyRaftGroupOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.raftop.NotifyTermChangeOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.RaftOp
Contains actual Raft operation logic.
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.raftop.snapshot.RestoreSnapshotOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.session.operation.CloseInactiveSessionsOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.session.operation.CloseSessionOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.session.operation.CreateSessionOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.session.operation.ExpireSessionsOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.session.operation.GenerateThreadIdOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.session.operation.GetSessionsOp
 
run(CPGroupId, long) - Method in class com.hazelcast.cp.internal.session.operation.HeartbeatSessionOp
 
run() - Method in class com.hazelcast.cp.internal.util.PartitionSpecificRunnableAdaptor
 
run() - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorContainer.TaskProcessor
 
run() - Method in class com.hazelcast.durableexecutor.impl.operations.DisposeResultBackupOperation
 
run() - Method in class com.hazelcast.durableexecutor.impl.operations.DisposeResultOperation
 
run() - Method in class com.hazelcast.durableexecutor.impl.operations.PutResultBackupOperation
 
run() - Method in class com.hazelcast.durableexecutor.impl.operations.PutResultOperation
 
run() - Method in class com.hazelcast.durableexecutor.impl.operations.ReplicationOperation
 
run() - Method in class com.hazelcast.durableexecutor.impl.operations.RetrieveAndDisposeResultOperation
 
run() - Method in class com.hazelcast.durableexecutor.impl.operations.RetrieveResultOperation
 
run() - Method in class com.hazelcast.durableexecutor.impl.operations.ShutdownOperation
 
run() - Method in class com.hazelcast.durableexecutor.impl.operations.TaskBackupOperation
 
run() - Method in class com.hazelcast.durableexecutor.impl.operations.TaskOperation
 
run() - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
 
run() - Method in class com.hazelcast.executor.impl.operations.ShutdownOperation
 
run() - Method in class com.hazelcast.instance.impl.Node.NodeShutdownHookThread
 
run() - Method in class com.hazelcast.internal.cluster.impl.MulticastService
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.AuthenticationFailureOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.BeforeJoinCheckFailureOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.ClusterMismatchOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.CommitClusterStateOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.ConfigMismatchOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.ExplicitSuspicionOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.FetchMembersViewOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.FinalizeJoinOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.HeartbeatComplaintOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.HeartbeatOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.JoinMastershipClaimOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.JoinRequestOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.LockClusterStateOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.MasterResponseOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.MemberAttributeChangedOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.MembersUpdateOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.MergeClustersOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.OnJoinOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.PromoteLiteMemberOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.RollbackClusterStateOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.ShutdownNodeOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.SplitBrainMergeValidationOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.TriggerExplicitSuspicionOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.TriggerMemberListPublishOp
 
run() - Method in class com.hazelcast.internal.cluster.impl.operations.WhoisMasterOp
 
run() - Method in class com.hazelcast.internal.crdt.AbstractCRDTReplicationOperation
 
run() - Method in class com.hazelcast.internal.crdt.pncounter.operations.AddOperation
 
run() - Method in class com.hazelcast.internal.crdt.pncounter.operations.GetOperation
 
run(DiagnosticsLogWriter) - Method in class com.hazelcast.internal.diagnostics.BuildInfoPlugin
 
run(DiagnosticsLogWriter) - Method in class com.hazelcast.internal.diagnostics.ConfigPropertiesPlugin
 
run(DiagnosticsLogWriter) - Method in class com.hazelcast.internal.diagnostics.DiagnosticsPlugin
 
run(DiagnosticsLogWriter) - Method in class com.hazelcast.internal.diagnostics.EventQueuePlugin
 
run(DiagnosticsLogWriter) - Method in class com.hazelcast.internal.diagnostics.InvocationPlugin
 
run(DiagnosticsLogWriter) - Method in class com.hazelcast.internal.diagnostics.MemberHazelcastInstanceInfoPlugin
 
run(DiagnosticsLogWriter) - Method in class com.hazelcast.internal.diagnostics.MemberHeartbeatPlugin
 
run(DiagnosticsLogWriter) - Method in class com.hazelcast.internal.diagnostics.MetricsPlugin
 
run(DiagnosticsLogWriter) - Method in class com.hazelcast.internal.diagnostics.NetworkingImbalancePlugin
 
run(DiagnosticsLogWriter) - Method in class com.hazelcast.internal.diagnostics.OperationHeartbeatPlugin
 
run(DiagnosticsLogWriter) - Method in class com.hazelcast.internal.diagnostics.OperationThreadSamplerPlugin
 
run(DiagnosticsLogWriter) - Method in class com.hazelcast.internal.diagnostics.OverloadedConnectionsPlugin
 
run(DiagnosticsLogWriter) - Method in class com.hazelcast.internal.diagnostics.PendingInvocationsPlugin
 
run(DiagnosticsLogWriter) - Method in class com.hazelcast.internal.diagnostics.SlowOperationPlugin
 
run(DiagnosticsLogWriter) - Method in class com.hazelcast.internal.diagnostics.StoreLatencyPlugin
 
run(DiagnosticsLogWriter) - Method in class com.hazelcast.internal.diagnostics.SystemLogPlugin
 
run(DiagnosticsLogWriter) - Method in class com.hazelcast.internal.diagnostics.SystemPropertiesPlugin
 
run() - Method in class com.hazelcast.internal.dynamicconfig.AddDynamicConfigOperation
 
run() - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService.Merger
 
run() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigPreJoinOperation
 
run() - Method in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
run() - Method in class com.hazelcast.internal.journal.EventJournalReadOperation
 
run() - Method in class com.hazelcast.internal.locksupport.operations.IsLockedOperation
 
run() - Method in class com.hazelcast.internal.locksupport.operations.LocalLockCleanupOperation
 
run() - Method in class com.hazelcast.internal.locksupport.operations.LockBackupOperation
 
run() - Method in class com.hazelcast.internal.locksupport.operations.LockOperation
 
run() - Method in class com.hazelcast.internal.locksupport.operations.LockReplicationOperation
 
run() - Method in class com.hazelcast.internal.locksupport.operations.UnlockBackupOperation
 
run() - Method in class com.hazelcast.internal.locksupport.operations.UnlockIfLeaseExpiredOperation
 
run() - Method in class com.hazelcast.internal.locksupport.operations.UnlockOperation
 
run() - Method in class com.hazelcast.internal.longregister.operations.AddAndGetOperation
 
run() - Method in class com.hazelcast.internal.longregister.operations.AddBackupOperation
 
run() - Method in class com.hazelcast.internal.longregister.operations.GetAndAddOperation
 
run() - Method in class com.hazelcast.internal.longregister.operations.GetAndSetOperation
 
run() - Method in class com.hazelcast.internal.longregister.operations.GetOperation
 
run() - Method in class com.hazelcast.internal.longregister.operations.LongRegisterReplicationOperation
 
run() - Method in class com.hazelcast.internal.longregister.operations.SetBackupOperation
 
run() - Method in class com.hazelcast.internal.longregister.operations.SetOperation
 
run() - Method in class com.hazelcast.internal.management.operation.ChangeWanStateOperation
 
run() - Method in class com.hazelcast.internal.management.operation.ClearWanQueuesOperation
 
run() - Method in class com.hazelcast.internal.management.operation.GetMapConfigOperation
 
run() - Method in class com.hazelcast.internal.management.operation.ScriptExecutorOperation
 
run() - Method in class com.hazelcast.internal.management.operation.SetLicenseOperation
 
run() - Method in class com.hazelcast.internal.management.operation.ThreadDumpOperation
 
run() - Method in class com.hazelcast.internal.management.operation.UpdateManagementCenterUrlOperation
 
run() - Method in class com.hazelcast.internal.management.operation.UpdateMapConfigOperation
 
run() - Method in class com.hazelcast.internal.management.operation.UpdatePermissionConfigOperation
 
run() - Method in class com.hazelcast.internal.management.operation.WanCheckConsistencyOperation
 
run() - Method in class com.hazelcast.internal.metrics.managementcenter.ReadMetricsOperation
 
run() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingTask
 
run() - Method in class com.hazelcast.internal.networking.nio.NioPipeline
 
run() - Method in class com.hazelcast.internal.networking.nio.NioThread
 
run() - Method in class com.hazelcast.internal.partition.operation.AssignPartitions
 
run() - Method in class com.hazelcast.internal.partition.operation.FetchPartitionStateOperation
 
run() - Method in class com.hazelcast.internal.partition.operation.FinalizeMigrationOperation
 
run() - Method in class com.hazelcast.internal.partition.operation.HasOngoingMigration
 
run() - Method in class com.hazelcast.internal.partition.operation.MigrationCommitOperation
 
run() - Method in class com.hazelcast.internal.partition.operation.MigrationOperation
Runs the operation.
run() - Method in class com.hazelcast.internal.partition.operation.PartitionBackupReplicaAntiEntropyOperation
 
run() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRequest
 
run() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncResponse
 
run() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRetryResponse
 
run() - Method in class com.hazelcast.internal.partition.operation.PartitionStateOperation
 
run() - Method in class com.hazelcast.internal.partition.operation.PartitionStateVersionCheckOperation
 
run() - Method in class com.hazelcast.internal.partition.operation.PublishCompletedMigrationsOperation
 
run() - Method in class com.hazelcast.internal.partition.operation.SafeStateCheckOperation
 
run() - Method in class com.hazelcast.internal.partition.operation.ShutdownRequestOperation
 
run() - Method in class com.hazelcast.internal.partition.operation.ShutdownResponseOperation
 
run() - Method in class com.hazelcast.internal.usercodedeployment.impl.operation.ClassDataFinderOperation
 
run() - Method in class com.hazelcast.internal.usercodedeployment.impl.operation.DeployClassesOperation
 
run() - Method in class com.hazelcast.internal.util.executor.CompletableFutureTask
 
run() - Method in class com.hazelcast.internal.util.executor.HazelcastManagedThread
Manages the thread lifecycle and can be overridden to customize if needed.
run() - Method in class com.hazelcast.internal.util.LocalRetryableExecution
 
run() - Method in class com.hazelcast.map.impl.mapstore.writebehind.StoreWorker
 
run() - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperation
 
run() - Method in class com.hazelcast.map.impl.operation.MapClearExpiredOperation
 
run() - Method in class com.hazelcast.map.impl.operation.MapGetInvalidationMetaDataOperation
 
run() - Method in class com.hazelcast.map.impl.operation.MapOperation
 
run() - Method in class com.hazelcast.map.impl.operation.MapPartitionDestroyOperation
 
run() - Method in class com.hazelcast.map.impl.operation.MapReplicationOperation
 
run() - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
 
run() - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
 
run(String, Predicate, int, Result) - Method in class com.hazelcast.map.impl.query.PartitionScanRunner
 
run(String, Predicate, int, int, int) - Method in class com.hazelcast.map.impl.query.PartitionScanRunner
Executes the predicate on a partition chunk.
run() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorScannerTask
 
run() - Method in class com.hazelcast.map.impl.querycache.accumulator.ConsumeAccumulatorOperation
 
run() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.PublisherCreateOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.ClearBackupOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.ClearOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.CountOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.DeleteBackupOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.DeleteOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.EntrySetOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.GetAllOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.KeySetOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.MergeBackupOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.MergeOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.MultiMapReplicationOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.PutBackupOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.PutOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllBackupOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.RemoveBackupOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.SizeOperation
 
run() - Method in class com.hazelcast.multimap.impl.operations.ValuesOperation
 
run() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitBackupOperation
 
run() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
 
run() - Method in class com.hazelcast.multimap.impl.txn.TxnGenerateRecordIdOperation
 
run() - Method in class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
 
run() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareBackupOperation
 
run() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
 
run() - Method in class com.hazelcast.multimap.impl.txn.TxnPutBackupOperation
 
run() - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
 
run() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllBackupOperation
 
run() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
 
run() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveBackupOperation
 
run() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
 
run() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackBackupOperation
 
run() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.CheckReplicaVersionOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsKeyOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsValueOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.EntrySetOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.EvictionOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.GetOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.IsEmptyOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.KeySetOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.MergeOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.PutAllOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.PutOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.RemoveOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateToCallerOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicationOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.RequestMapDataOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.SizeOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.SyncReplicatedMapDataOperation
 
run() - Method in class com.hazelcast.replicatedmap.impl.operation.ValuesOperation
 
run() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllBackupOperation
 
run() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
 
run() - Method in class com.hazelcast.ringbuffer.impl.operations.AddBackupOperation
 
run() - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
 
run() - Method in class com.hazelcast.ringbuffer.impl.operations.GenericOperation
 
run() - Method in class com.hazelcast.ringbuffer.impl.operations.MergeBackupOperation
 
run() - Method in class com.hazelcast.ringbuffer.impl.operations.MergeOperation
 
run() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
 
run() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
 
run() - Method in class com.hazelcast.ringbuffer.impl.operations.ReplicationOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.NamedTaskDecorator
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.CancelTaskBackupOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.CancelTaskOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.DisposeBackupTaskOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.DisposeTaskOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnMemberOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnPartitionOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetDelayOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetResultOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetStatisticsOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.IsCanceledOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.IsDoneOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.MergeBackupOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.MergeOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.ReplicationOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.ResultReadyNotifyOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.ScheduleTaskBackupOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.ScheduleTaskOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.ShutdownOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.SyncBackupStateOperation
 
run() - Method in class com.hazelcast.scheduledexecutor.impl.operations.SyncStateOperation
 
run() - Method in class com.hazelcast.spi.discovery.multicast.impl.MulticastDiscoverySender
 
run() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventProcessor
 
run() - Method in class com.hazelcast.spi.impl.eventservice.impl.LocalEventDispatcher
 
run() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.OnJoinRegistrationOperation
 
run() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.SendEventOperation
 
run() - Method in class com.hazelcast.spi.impl.eventservice.impl.RemoteEventProcessor
 
run() - Method in class com.hazelcast.spi.impl.executionservice.impl.DelegateAndSkipOnConcurrentExecutionDecorator
 
run() - Method in class com.hazelcast.spi.impl.merge.AbstractContainerCollector
Collects the containers from the data structure in a thread-safe way.
run() - Method in class com.hazelcast.spi.impl.merge.AbstractContainerMerger
 
run() - Method in class com.hazelcast.spi.impl.merge.AbstractMergeRunnable
 
run(Operation) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
run() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationThread
 
run(Operation) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
Runs the Operation on the calling thread.
run(Packet) - Method in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
 
run(Runnable) - Method in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
 
run(Operation) - Method in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
 
run() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
 
run(Operation) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
run() - Method in class com.hazelcast.spi.impl.operationservice.Operation
Runs the operation.
run(Operation) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Runs an operation in the calling thread.
run() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.DistributedObjectDestroyOperation
 
run() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.InitializeDistributedObjectOperation
 
run() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.PostJoinProxyOperation
 
run() - Method in class com.hazelcast.topic.impl.PublishOperation
 
run() - Method in class com.hazelcast.transaction.impl.operations.BroadcastTxRollbackOperation
 
run() - Method in class com.hazelcast.transaction.impl.operations.CreateAllowedDuringPassiveStateTxBackupLogOperation
 
run() - Method in class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
 
run() - Method in class com.hazelcast.transaction.impl.operations.PurgeTxBackupLogOperation
 
run() - Method in class com.hazelcast.transaction.impl.operations.ReplicateTxBackupLogOperation
 
run() - Method in class com.hazelcast.transaction.impl.operations.RollbackTxBackupLogOperation
 
run() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionBackupOperation
 
run() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
 
run() - Method in class com.hazelcast.transaction.impl.xa.operations.CollectRemoteTransactionsOperation
 
run() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionBackupOperation
 
run() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
 
run() - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionBackupOperation
 
run() - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionOperation
 
run() - Method in class com.hazelcast.transaction.impl.xa.operations.XaReplicationOperation
 
runAfterBoth(CompletionStage<?>, Runnable) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
runAfterBoth(CompletionStage<?>, Runnable) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
runAfterBoth(CompletionStage<?>, Runnable) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
runAfterBoth(CompletionStage<?>, Runnable) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
runAfterBothAsync(CompletionStage<?>, Runnable) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
runAfterBothAsync(CompletionStage<?>, Runnable, Executor) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
runAfterBothAsync(CompletionStage<?>, Runnable, Executor) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
runAfterBothAsync(CompletionStage<?>, Runnable) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
runAfterBothAsync(CompletionStage<?>, Runnable, Executor) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
runAfterBothAsync(CompletionStage<?>, Runnable) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
runAfterBothAsync(CompletionStage<?>, Runnable, Executor) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
runAfterBothAsync(CompletionStage<?>, Runnable) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
runAfterBothAsync(CompletionStage<?>, Runnable, Executor) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
runAfterEither(CompletionStage<?>, Runnable) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
runAfterEither(CompletionStage<?>, Runnable) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
runAfterEither(CompletionStage<?>, Runnable) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
runAfterEither(CompletionStage<?>, Runnable) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
runAfterEitherAsync(CompletionStage<?>, Runnable) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
runAfterEitherAsync(CompletionStage<?>, Runnable, Executor) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
runAfterEitherAsync(CompletionStage<?>, Runnable, Executor) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
runAfterEitherAsync(CompletionStage<?>, Runnable) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
runAfterEitherAsync(CompletionStage<?>, Runnable, Executor) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
runAfterEitherAsync(CompletionStage<?>, Runnable) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
runAfterEitherAsync(CompletionStage<?>, Runnable, Executor) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
runAfterEitherAsync(CompletionStage<?>, Runnable) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
runAfterEitherAsync(CompletionStage<?>, Runnable, Executor) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
runDirect(Operation) - Static method in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
Runs operation directly without checking any conditions; node state, partition ownership, timeouts etc.
RunGcRequest - Class in com.hazelcast.internal.management.request
Request for invoking Garbage Collection on the node.
RunGcRequest() - Constructor for class com.hazelcast.internal.management.request.RunGcRequest
 
runIndexOrPartitionScanQueryOnOwnedPartitions(Query) - Method in class com.hazelcast.map.impl.query.QueryRunner
 
runIndexQueryOnOwnedPartitions(Query) - Method in class com.hazelcast.map.impl.query.QueryRunner
Performs the given query using indexes.
runInternal() - Method in class com.hazelcast.map.impl.journal.MapEventJournalSubscribeOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.AddIndexBackupOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.AddIndexOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.AwaitMapFlushOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.ClearBackupOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.ClearOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.ContainsKeyOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.ContainsValueOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.DeleteOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.EntryBackupOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.EntryOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.EvictAllBackupOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.EvictBackupOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.EvictBatchBackupOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.EvictOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.GetAllOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.GetEntryViewOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.GetOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.IsKeyLoadFinishedOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.IsPartitionLoadedOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.KeyLoadStatusOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.LoadAllOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.LoadMapOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.MapFetchEntriesOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.MapFetchKeysOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.MapFetchWithQueryOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.MapFlushBackupOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.MapFlushOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.MapIsEmptyOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.MapOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.MapSizeOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.MergeOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.MultipleEntryBackupOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.NotifyMapFlushOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryBackupOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.PutAllBackupOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllBackupOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.PutIfAbsentOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.PutOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.PutTransientOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.RemoveBackupOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.RemoveFromLoadAllOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.RemoveIfSameOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.RemoveOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.ReplaceOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.SetOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.SetTtlBackupOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.SetTtlOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.TriggerLoadIfNeededOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.TryPutOperation
 
runInternal() - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
 
runInternal() - Method in class com.hazelcast.map.impl.query.QueryPartitionOperation
 
runInternal() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.DestroyQueryCacheOperation
 
runInternal() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.MadePublishableOperation
 
runInternal() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.ReadAndResetAccumulatorOperation
 
runInternal() - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.SetReadCursorOperation
 
runInternal() - Method in class com.hazelcast.map.impl.tx.TxnDeleteBackupOperation
 
runInternal() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
 
runInternal() - Method in class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
 
runInternal() - Method in class com.hazelcast.map.impl.tx.TxnPrepareBackupOperation
 
runInternal() - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
 
runInternal() - Method in class com.hazelcast.map.impl.tx.TxnRollbackBackupOperation
 
runInternal() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
 
runInternal() - Method in class com.hazelcast.map.impl.tx.TxnSetBackupOperation
 
runInternal() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
 
runInternal() - Method in class com.hazelcast.map.impl.tx.TxnUnlockBackupOperation
 
runInternal() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
 
runInternal() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.DeregistrationOperation
 
runInternal() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.RegistrationOperation
 
runInternal() - Method in class com.hazelcast.spi.impl.merge.AbstractContainerMerger
Executes the service specific merging logic.
RUNNABLE_ADAPTER - Static variable in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
 
RUNNABLE_ADAPTER - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
RUNNABLE_DEFINITION - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
RunnableAdapter<V> - Class in com.hazelcast.executor.impl
An adapter that adapts a Runnable to become a Callable.
RunnableAdapter() - Constructor for class com.hazelcast.executor.impl.RunnableAdapter
 
RunnableAdapter(Runnable) - Constructor for class com.hazelcast.executor.impl.RunnableAdapter
 
runningOperations() - Method in class com.hazelcast.spi.impl.operationservice.OperationControl
 
runningOperationsCount - Variable in class com.hazelcast.internal.management.dto.OperationServiceDTO
 
runOperation(Object, long) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Executes the operation on underlying operation execution mechanism and returns its return value.
runOrExecute(Operation) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
runOrExecute(Operation) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
Tries to run the Operation on the calling thread if allowed.
runPartitionIndexOrPartitionScanQueryOnGivenOwnedPartition(Query, int) - Method in class com.hazelcast.map.impl.query.QueryRunner
 
runPartitionScanForPartition(String, Predicate, int, Result) - Method in class com.hazelcast.map.impl.query.ParallelPartitionScanExecutor
 
runPartitionScanQueryOnPartitionChunk(Query, int, int, int) - Method in class com.hazelcast.map.impl.query.QueryRunner
Runs a query on a chunk of a single partition.
runQuery(Object, InternalCompletableFuture) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Executes query operation sets execution result to the future.
RUNTIME - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
RuntimeAvailableProcessors - Class in com.hazelcast.internal.util
Utility class to access Runtime.availableProcessors() and optionally override its return value.
RuntimeInterruptedException - Exception in com.hazelcast.core
An unchecked version of InterruptedException.
RuntimeInterruptedException() - Constructor for exception com.hazelcast.core.RuntimeInterruptedException
 
RuntimeInterruptedException(String) - Constructor for exception com.hazelcast.core.RuntimeInterruptedException
 
RuntimeMemoryInfoAccessor - Class in com.hazelcast.internal.util
Provides memory information using Runtime.
RuntimeMemoryInfoAccessor() - Constructor for class com.hazelcast.internal.util.RuntimeMemoryInfoAccessor
 
RuntimeMetricSet - Class in com.hazelcast.internal.metrics.metricsets
A Metric pack for exposing Runtime metrics.
runUnderLifecycleLock(Runnable) - Method in class com.hazelcast.instance.impl.LifecycleServiceImpl
 
runUsingGlobalIndexSafely(Predicate, MapContainer, int) - Method in class com.hazelcast.map.impl.query.QueryRunner
 
runUsingPartitionScanSafely(Query, Predicate, PartitionIdSet, int) - Method in class com.hazelcast.map.impl.query.QueryRunner
 
runUsingPartitionScanWithoutPaging(String, Predicate, Collection<Integer>, Result) - Method in class com.hazelcast.map.impl.query.ParallelPartitionScanExecutor
 
runWithPartitionScanForNative() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryBackupOperation
 

S

SAFE_STATE_CHECK - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
safeRegister(Class, Serializer) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
safeRegister(Class, SerializerAdapter) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
SafeStateCheckOperation - Class in com.hazelcast.internal.partition.operation
Checks whether a node is safe or not.
SafeStateCheckOperation() - Constructor for class com.hazelcast.internal.partition.operation.SafeStateCheckOperation
 
sample(int) - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap
 
sample(int) - Method in interface com.hazelcast.internal.eviction.impl.strategy.sampling.SampleableEvictableStore
The sample method is used to sample a number of entries (defined by the samples parameter) from the internal data structure.
sample(int) - Method in class com.hazelcast.internal.nearcache.impl.store.HeapNearCacheRecordMap
 
sample(int) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordHashMap
 
SAMPLE_COUNT - Static variable in interface com.hazelcast.map.impl.eviction.Evictor
 
SAMPLE_PERIOD_SECONDS - Static variable in class com.hazelcast.internal.diagnostics.InvocationPlugin
The sample period in seconds.
SampleableCacheRecordMap<K extends Data,V extends CacheRecord> - Interface in com.hazelcast.cache.impl.record
 
SampleableConcurrentHashMap<K,V> - Class in com.hazelcast.internal.util
ConcurrentHashMap to extend iterator capability.
SampleableConcurrentHashMap(int) - Constructor for class com.hazelcast.internal.util.SampleableConcurrentHashMap
 
SampleableConcurrentHashMap(int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType) - Constructor for class com.hazelcast.internal.util.SampleableConcurrentHashMap
 
SampleableConcurrentHashMap.SamplingEntry<K,V> - Class in com.hazelcast.internal.util
Entry to define keys and values for sampling.
SampleableEvictableStore<A,E extends Evictable> - Interface in com.hazelcast.internal.eviction.impl.strategy.sampling
Interface for sampleable store implementations that holds Evictable entries to evict.
SampleableNearCacheRecordMap<K,V extends NearCacheRecord> - Interface in com.hazelcast.internal.nearcache.impl
Contract point for all record maps which support entry sampling to be used for storage in Near Cache.
sampleAndForceRemoveEntries(int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
sampleAndForceRemoveEntries(int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
 
sampleAndForceRemoveEntries(int) - Method in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
sampleAndForceRemoveEntries(int) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
SAMPLER_PERIOD_MILLIS - Static variable in class com.hazelcast.internal.diagnostics.OperationThreadSamplerPlugin
The period in milliseconds between taking samples.
SAMPLES - Static variable in class com.hazelcast.internal.diagnostics.EventQueuePlugin
The number of samples to take from the event queue.
SAMPLES - Static variable in class com.hazelcast.internal.diagnostics.OverloadedConnectionsPlugin
The number of samples to take from a single overloaded connection.
SamplingEntry(K, V) - Constructor for class com.hazelcast.internal.util.SampleableConcurrentHashMap.SamplingEntry
 
SamplingEvictionStrategy<A,E extends Evictable,S extends SampleableEvictableStore<A,E>> - Class in com.hazelcast.internal.eviction.impl.strategy.sampling
This strategy samples Evictable entries from SampleableEvictableStore, orders candidates for eviction according to the provided EvictionPolicyEvaluator.
save(Map) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledRunnableAdapter
 
save(Map<K, V>) - Method in interface com.hazelcast.scheduledexecutor.StatefulTask
Task callback to capture its state on the provided map.
saveCurrentTenant(DestroyEventContext) - Method in class com.hazelcast.spi.impl.tenantcontrol.NoopTenantControlFactory
 
saveCurrentTenant(DestroyEventContext) - Method in interface com.hazelcast.spi.tenantcontrol.TenantControlFactory
To be called from the application's thread to connect a Hazelcast object with a particular tenant, e.g.
schedule(Runnable, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
schedule(Callable<V>, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
schedule(Runnable, long, TimeUnit) - Method in class com.hazelcast.client.impl.spi.impl.ClientExecutionServiceImpl
 
schedule(Callable<V>, long, TimeUnit) - Method in class com.hazelcast.client.impl.spi.impl.ClientExecutionServiceImpl
 
schedule(Runnable, long, TimeUnit) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Schedules the task on the underlying platform to be executed after the given delay.
schedule(Runnable, long) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
schedule(long, K, V) - Method in interface com.hazelcast.internal.util.scheduler.EntryTaskScheduler
Schedules (or reschedules) the execution of given entry.
schedule(long, K, V) - Method in class com.hazelcast.internal.util.scheduler.SecondsBasedEntryTaskScheduler
 
schedule(TaskDefinition) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
schedule(TaskDefinition) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorMemberOwnedContainer
 
schedule(Runnable, long, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
schedule(Callable<V>, long, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
schedule(Runnable, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay.
schedule(Callable<V>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay.
schedule(Runnable, long, TimeUnit) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
schedule(String, Runnable, long, TimeUnit) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
schedule(Runnable, long, TimeUnit) - Method in class com.hazelcast.spi.impl.executionservice.impl.DelegatingTaskScheduler
 
schedule(Callable<V>, long, TimeUnit) - Method in class com.hazelcast.spi.impl.executionservice.impl.DelegatingTaskScheduler
 
schedule(Runnable, long, TimeUnit) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
schedule(String, Runnable, long, TimeUnit) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
schedule(Runnable, long, TimeUnit) - Method in interface com.hazelcast.spi.impl.executionservice.TaskScheduler
Creates and executes a one-shot action that becomes enabled after the given delay.
schedule(Callable<V>, long, TimeUnit) - Method in interface com.hazelcast.spi.impl.executionservice.TaskScheduler
Creates and executes a one-shot action that becomes enabled after the given delay.
SCHEDULE_BACKUP_OP - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
SCHEDULE_OP - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
scheduleAtFixedRate(Runnable, long, TimeUnit, ProbeLevel) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
 
scheduleAtFixedRate(Runnable, long, TimeUnit, ProbeLevel) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
Schedules a publisher to be executed at a fixed rate.
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period.
scheduleClusterVersionAutoUpgrade() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
scheduleClusterVersionAutoUpgrade() - Method in interface com.hazelcast.instance.impl.NodeExtension
Cluster version auto upgrade is done asynchronously.
SCHEDULED_EXECUTOR - Static variable in interface com.hazelcast.spi.impl.executionservice.ExecutionService
Name of the scheduled executor.
SCHEDULED_EXECUTOR_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SCHEDULED_EXECUTOR_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
SCHEDULED_EXECUTOR_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
SCHEDULED_EXECUTOR_MERGING_ENTRY - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
scheduleDeferred(Runnable, long, TimeUnit) - Method in interface com.hazelcast.internal.nio.NetworkingService
Global scheduler for all Endpoints responsible of message retransmission
scheduleDeferred(Runnable, long, TimeUnit) - Method in class com.hazelcast.internal.nio.tcp.TcpIpNetworkingService
 
ScheduledEntry<K,V> - Class in com.hazelcast.internal.util.scheduler
Entry wrapper with schedule time information to be used in SecondsBasedEntryTaskScheduler.
ScheduledEntry(K, V, long, int, long) - Constructor for class com.hazelcast.internal.util.scheduler.ScheduledEntry
 
ScheduledEntryProcessor<K,V> - Interface in com.hazelcast.internal.util.scheduler
 
ScheduledExecutorCancelFromAddressCodec - Class in com.hazelcast.client.impl.protocol.codec
Cancels further execution and scheduling of the task
ScheduledExecutorCancelFromAddressCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorCancelFromAddressCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorCancelFromPartitionCodec - Class in com.hazelcast.client.impl.protocol.codec
Cancels further execution and scheduling of the task
ScheduledExecutorCancelFromPartitionCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorCancelFromPartitionCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorConfig - Class in com.hazelcast.config
Configuration options for the IScheduledExecutorService.
ScheduledExecutorConfig() - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorConfig(String) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorConfig(String, int, int, int) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorConfig(String, int, int, int, String, MergePolicyConfig) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorConfig(ScheduledExecutorConfig) - Constructor for class com.hazelcast.config.ScheduledExecutorConfig
 
ScheduledExecutorConfigReadOnly - Class in com.hazelcast.internal.config
 
ScheduledExecutorConfigReadOnly(ScheduledExecutorConfig) - Constructor for class com.hazelcast.internal.config.ScheduledExecutorConfigReadOnly
 
ScheduledExecutorContainer - Class in com.hazelcast.scheduledexecutor.impl
 
ScheduledExecutorContainerHolder - Interface in com.hazelcast.scheduledexecutor.impl
 
ScheduledExecutorDataSerializerHook - Class in com.hazelcast.scheduledexecutor.impl
 
ScheduledExecutorDataSerializerHook() - Constructor for class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
ScheduledExecutorDisposeFromAddressCodec - Class in com.hazelcast.client.impl.protocol.codec
Dispose the task from the scheduler
ScheduledExecutorDisposeFromAddressCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorDisposeFromAddressCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorDisposeFromPartitionCodec - Class in com.hazelcast.client.impl.protocol.codec
Dispose the task from the scheduler
ScheduledExecutorDisposeFromPartitionCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorDisposeFromPartitionCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorGetAllScheduledFuturesCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns all scheduled tasks in for a given scheduler in the given member.
ScheduledExecutorGetAllScheduledFuturesCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorGetAllScheduledFuturesCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorGetAllScheduledMessageTask - Class in com.hazelcast.client.impl.protocol.task.scheduledexecutor
 
ScheduledExecutorGetAllScheduledMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorGetAllScheduledMessageTask
 
ScheduledExecutorGetDelayFromAddressCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the ScheduledFuture's delay in nanoseconds for the task in the scheduler.
ScheduledExecutorGetDelayFromAddressCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorGetDelayFromAddressCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorGetDelayFromPartitionCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the ScheduledFuture's delay in nanoseconds for the task in the scheduler.
ScheduledExecutorGetDelayFromPartitionCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorGetDelayFromPartitionCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorGetResultFromAddressCodec - Class in com.hazelcast.client.impl.protocol.codec
Fetches the result of the task (Callable) The call will blocking until the result is ready.
ScheduledExecutorGetResultFromAddressCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorGetResultFromAddressCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorGetResultFromPartitionCodec - Class in com.hazelcast.client.impl.protocol.codec
Fetches the result of the task (Callable) The call will blocking until the result is ready.
ScheduledExecutorGetResultFromPartitionCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorGetResultFromPartitionCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorGetStatsFromAddressCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns statistics of the task
ScheduledExecutorGetStatsFromAddressCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorGetStatsFromAddressCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorGetStatsFromPartitionCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns statistics of the task
ScheduledExecutorGetStatsFromPartitionCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorGetStatsFromPartitionCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorIsCancelledFromAddressCodec - Class in com.hazelcast.client.impl.protocol.codec
Checks whether a task as identified from the given handler is already cancelled.
ScheduledExecutorIsCancelledFromAddressCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorIsCancelledFromAddressCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorIsCancelledFromPartitionCodec - Class in com.hazelcast.client.impl.protocol.codec
Checks whether a task as identified from the given handler is already cancelled.
ScheduledExecutorIsCancelledFromPartitionCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorIsCancelledFromPartitionCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorIsDoneFromAddressCodec - Class in com.hazelcast.client.impl.protocol.codec
Checks whether a task is done.
ScheduledExecutorIsDoneFromAddressCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorIsDoneFromAddressCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorIsDoneFromPartitionCodec - Class in com.hazelcast.client.impl.protocol.codec
Checks whether a task is done.
ScheduledExecutorIsDoneFromPartitionCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorIsDoneFromPartitionCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorMemberBin - Class in com.hazelcast.scheduledexecutor.impl
 
ScheduledExecutorMemberBin(NodeEngine) - Constructor for class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorMemberBin
 
ScheduledExecutorMemberOwnedContainer - Class in com.hazelcast.scheduledexecutor.impl
Container for member owned Schedulers.
ScheduledExecutorMergingEntryImpl - Class in com.hazelcast.spi.impl.merge
ScheduledExecutorMergingEntryImpl() - Constructor for class com.hazelcast.spi.impl.merge.ScheduledExecutorMergingEntryImpl
 
ScheduledExecutorMergingEntryImpl(SerializationService) - Constructor for class com.hazelcast.spi.impl.merge.ScheduledExecutorMergingEntryImpl
 
ScheduledExecutorPartition - Class in com.hazelcast.scheduledexecutor.impl
 
ScheduledExecutorPermission - Class in com.hazelcast.security.permission
 
ScheduledExecutorPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ScheduledExecutorPermission
 
ScheduledExecutorServiceProxy - Class in com.hazelcast.scheduledexecutor.impl
 
ScheduledExecutorShutdownCodec - Class in com.hazelcast.client.impl.protocol.codec
Initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
ScheduledExecutorShutdownCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorShutdownCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorShutdownMessageTask - Class in com.hazelcast.client.impl.protocol.task.scheduledexecutor
 
ScheduledExecutorShutdownMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorShutdownMessageTask
 
ScheduledExecutorSubmitToAddressCodec - Class in com.hazelcast.client.impl.protocol.codec
Submits the task to a member for execution, member is provided in the form of an address.
ScheduledExecutorSubmitToAddressCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorSubmitToAddressCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorSubmitToAddressMessageTask - Class in com.hazelcast.client.impl.protocol.task.scheduledexecutor
 
ScheduledExecutorSubmitToAddressMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToAddressMessageTask
 
ScheduledExecutorSubmitToPartitionCodec - Class in com.hazelcast.client.impl.protocol.codec
Submits the task to partition for execution, partition is chosen based on multiple criteria of the given task.
ScheduledExecutorSubmitToPartitionCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorSubmitToPartitionCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
ScheduledExecutorSubmitToPartitionMessageTask - Class in com.hazelcast.client.impl.protocol.task.scheduledexecutor
 
ScheduledExecutorSubmitToPartitionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorSubmitToPartitionMessageTask
 
ScheduledExecutorTaskCancelFromAddressMessageTask - Class in com.hazelcast.client.impl.protocol.task.scheduledexecutor
 
ScheduledExecutorTaskCancelFromAddressMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromAddressMessageTask
 
ScheduledExecutorTaskCancelFromPartitionMessageTask - Class in com.hazelcast.client.impl.protocol.task.scheduledexecutor
 
ScheduledExecutorTaskCancelFromPartitionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskCancelFromPartitionMessageTask
 
ScheduledExecutorTaskDisposeFromAddressMessageTask - Class in com.hazelcast.client.impl.protocol.task.scheduledexecutor
 
ScheduledExecutorTaskDisposeFromAddressMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromAddressMessageTask
 
ScheduledExecutorTaskDisposeFromPartitionMessageTask - Class in com.hazelcast.client.impl.protocol.task.scheduledexecutor
 
ScheduledExecutorTaskDisposeFromPartitionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskDisposeFromPartitionMessageTask
 
ScheduledExecutorTaskGetDelayFromAddressMessageTask - Class in com.hazelcast.client.impl.protocol.task.scheduledexecutor
 
ScheduledExecutorTaskGetDelayFromAddressMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromAddressMessageTask
 
ScheduledExecutorTaskGetDelayFromPartitionMessageTask - Class in com.hazelcast.client.impl.protocol.task.scheduledexecutor
 
ScheduledExecutorTaskGetDelayFromPartitionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetDelayFromPartitionMessageTask
 
ScheduledExecutorTaskGetResultFromAddressMessageTask - Class in com.hazelcast.client.impl.protocol.task.scheduledexecutor
 
ScheduledExecutorTaskGetResultFromAddressMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromAddressMessageTask
 
ScheduledExecutorTaskGetResultFromPartitionMessageTask - Class in com.hazelcast.client.impl.protocol.task.scheduledexecutor
 
ScheduledExecutorTaskGetResultFromPartitionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetResultFromPartitionMessageTask
 
ScheduledExecutorTaskGetStatisticsFromAddressMessageTask - Class in com.hazelcast.client.impl.protocol.task.scheduledexecutor
 
ScheduledExecutorTaskGetStatisticsFromAddressMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromAddressMessageTask
 
ScheduledExecutorTaskGetStatisticsFromPartitionMessageTask - Class in com.hazelcast.client.impl.protocol.task.scheduledexecutor
 
ScheduledExecutorTaskGetStatisticsFromPartitionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskGetStatisticsFromPartitionMessageTask
 
ScheduledExecutorTaskIsCancelledFromAddressMessageTask - Class in com.hazelcast.client.impl.protocol.task.scheduledexecutor
 
ScheduledExecutorTaskIsCancelledFromAddressMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromAddressMessageTask
 
ScheduledExecutorTaskIsCancelledFromPartitionMessageTask - Class in com.hazelcast.client.impl.protocol.task.scheduledexecutor
 
ScheduledExecutorTaskIsCancelledFromPartitionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsCancelledFromPartitionMessageTask
 
ScheduledExecutorTaskIsDoneFromAddressMessageTask - Class in com.hazelcast.client.impl.protocol.task.scheduledexecutor
 
ScheduledExecutorTaskIsDoneFromAddressMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromAddressMessageTask
 
ScheduledExecutorTaskIsDoneFromPartitionMessageTask - Class in com.hazelcast.client.impl.protocol.task.scheduledexecutor
 
ScheduledExecutorTaskIsDoneFromPartitionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.scheduledexecutor.ScheduledExecutorTaskIsDoneFromPartitionMessageTask
 
ScheduledExecutorWaitNotifyKey - Class in com.hazelcast.scheduledexecutor.impl
 
ScheduledExecutorWaitNotifyKey(String, String) - Constructor for class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorWaitNotifyKey
 
ScheduledFutureProxy<V> - Class in com.hazelcast.scheduledexecutor.impl
 
ScheduledRunnableAdapter<V> - Class in com.hazelcast.scheduledexecutor.impl
 
ScheduledRunnableAdapter() - Constructor for class com.hazelcast.scheduledexecutor.impl.ScheduledRunnableAdapter
 
ScheduledRunnableAdapter(Runnable) - Constructor for class com.hazelcast.scheduledexecutor.impl.ScheduledRunnableAdapter
 
ScheduledTaskDescriptor - Class in com.hazelcast.scheduledexecutor.impl
Metadata holder for scheduled tasks.
ScheduledTaskDescriptor() - Constructor for class com.hazelcast.scheduledexecutor.impl.ScheduledTaskDescriptor
 
ScheduledTaskDescriptor(TaskDefinition) - Constructor for class com.hazelcast.scheduledexecutor.impl.ScheduledTaskDescriptor
 
ScheduledTaskDescriptor(TaskDefinition, Map<?, ?>, ScheduledTaskStatisticsImpl, ScheduledTaskResult) - Constructor for class com.hazelcast.scheduledexecutor.impl.ScheduledTaskDescriptor
 
ScheduledTaskHandler - Class in com.hazelcast.scheduledexecutor
Resource handler pointing to a IScheduledFuture.
ScheduledTaskHandler() - Constructor for class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
 
ScheduledTaskHandlerAccessor - Class in com.hazelcast.scheduledexecutor.impl
 
ScheduledTaskHandlerCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
ScheduledTaskHandlerImpl - Class in com.hazelcast.scheduledexecutor.impl
 
ScheduledTaskHandlerImpl() - Constructor for class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
 
ScheduledTaskHandlerImpl(Address, int, String, String) - Constructor for class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
 
ScheduledTaskResult - Class in com.hazelcast.scheduledexecutor.impl
 
ScheduledTaskResult.ExecutionExceptionDecorator - Exception in com.hazelcast.scheduledexecutor.impl
 
ScheduledTaskStatistics - Interface in com.hazelcast.scheduledexecutor
Statistics and timing info for a IScheduledFuture accessible through IScheduledFuture.getStats()
ScheduledTaskStatisticsImpl - Class in com.hazelcast.scheduledexecutor.impl
 
ScheduledTaskStatisticsImpl() - Constructor for class com.hazelcast.scheduledexecutor.impl.ScheduledTaskStatisticsImpl
 
ScheduledTaskStatisticsImpl(ScheduledTaskStatisticsImpl) - Constructor for class com.hazelcast.scheduledexecutor.impl.ScheduledTaskStatisticsImpl
 
ScheduledTaskStatisticsImpl(long, long, long, long, long) - Constructor for class com.hazelcast.scheduledexecutor.impl.ScheduledTaskStatisticsImpl
 
scheduleDurable(String, Runnable, long, TimeUnit) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
scheduleDurable(String, Callable<V>, long, TimeUnit) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
scheduleDurable(String, Runnable, long, TimeUnit) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
scheduleDurable(String, Callable<V>, long, TimeUnit) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
scheduleDurableWithRepetition(String, Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
scheduleDurableWithRepetition(String, Runnable, long, long, TimeUnit) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
scheduleEviction(String, long) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
scheduleExpirationTask() - Method in class com.hazelcast.internal.eviction.ExpirationManager
Starts scheduling of the task that clears expired entries.
scheduleOnAllMembers(Runnable, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
scheduleOnAllMembers(Callable<V>, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
scheduleOnAllMembers(Runnable, long, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
scheduleOnAllMembers(Callable<V>, long, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
scheduleOnAllMembers(Runnable, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on all cluster Members.
scheduleOnAllMembers(Callable<V>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on all cluster Members.
scheduleOnAllMembersAtFixedRate(Runnable, long, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
scheduleOnAllMembersAtFixedRate(Runnable, long, long, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
scheduleOnAllMembersAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period on all cluster Members.
scheduleOnKeyOwner(Runnable, Object, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
scheduleOnKeyOwner(Callable<V>, Object, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
scheduleOnKeyOwner(Runnable, Object, long, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
scheduleOnKeyOwner(Callable<V>, Object, long, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
scheduleOnKeyOwner(Runnable, Object, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on the partition owner of the given key.
scheduleOnKeyOwner(Callable<V>, Object, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on the partition owner of the given key.
scheduleOnKeyOwnerAtFixedRate(Runnable, Object, long, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
scheduleOnKeyOwnerAtFixedRate(Runnable, Object, long, long, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
scheduleOnKeyOwnerAtFixedRate(Runnable, Object, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period on the partition owner of the given key.
scheduleOnMember(Runnable, Member, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
scheduleOnMember(Callable<V>, Member, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
scheduleOnMember(Runnable, Member, long, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
scheduleOnMember(Callable<V>, Member, long, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
scheduleOnMember(Runnable, Member, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay at the given Member.
scheduleOnMember(Callable<V>, Member, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay at the given Member.
scheduleOnMemberAtFixedRate(Runnable, Member, long, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
scheduleOnMemberAtFixedRate(Runnable, Member, long, long, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
scheduleOnMemberAtFixedRate(Runnable, Member, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period at the given Member.
scheduleOnMembers(Runnable, Collection<Member>, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
scheduleOnMembers(Callable<V>, Collection<Member>, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
scheduleOnMembers(Runnable, Collection<Member>, long, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
scheduleOnMembers(Callable<V>, Collection<Member>, long, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
scheduleOnMembers(Runnable, Collection<Member>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on all Members given.
scheduleOnMembers(Callable<V>, Collection<Member>, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay on all Members given.
scheduleOnMembersAtFixedRate(Runnable, Collection<Member>, long, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
scheduleOnMembersAtFixedRate(Runnable, Collection<Member>, long, long, TimeUnit) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
scheduleOnMembersAtFixedRate(Runnable, Collection<Member>, long, long, TimeUnit) - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period on all Members given.
scheduler - Variable in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
scheduler - Variable in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
 
schedulerName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromAddressCodec.RequestParameters
The name of the scheduler.
schedulerName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromPartitionCodec.RequestParameters
The name of the scheduler.
schedulerName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromAddressCodec.RequestParameters
The name of the scheduler.
schedulerName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromPartitionCodec.RequestParameters
The name of the scheduler.
schedulerName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetAllScheduledFuturesCodec.RequestParameters
The name of the scheduler.
schedulerName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromAddressCodec.RequestParameters
The name of the scheduler.
schedulerName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromPartitionCodec.RequestParameters
The name of the scheduler.
schedulerName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromAddressCodec.RequestParameters
The name of the scheduler.
schedulerName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromPartitionCodec.RequestParameters
The name of the scheduler.
schedulerName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromAddressCodec.RequestParameters
The name of the scheduler.
schedulerName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromPartitionCodec.RequestParameters
The name of the scheduler.
schedulerName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromAddressCodec.RequestParameters
The name of the scheduler.
schedulerName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromPartitionCodec.RequestParameters
The name of the scheduler.
schedulerName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromAddressCodec.RequestParameters
The name of the scheduler.
schedulerName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromPartitionCodec.RequestParameters
The name of the scheduler.
schedulerName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorShutdownCodec.RequestParameters
Name of the scheduler.
schedulerName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToAddressCodec.RequestParameters
The name of the scheduler.
schedulerName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToPartitionCodec.RequestParameters
The name of the scheduler.
schedulerName - Variable in class com.hazelcast.scheduledexecutor.impl.operations.AbstractSchedulerOperation
 
ScheduleTaskBackupOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
ScheduleTaskBackupOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.ScheduleTaskBackupOperation
 
ScheduleTaskBackupOperation(String, TaskDefinition) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.ScheduleTaskBackupOperation
 
ScheduleTaskOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
ScheduleTaskOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.ScheduleTaskOperation
 
ScheduleTaskOperation(String, TaskDefinition) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.ScheduleTaskOperation
 
scheduleTimeout(CPGroupId, String, UUID, long) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
scheduleTtlEntry(long, Object, Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
scheduleTtlEntry(long, Object, Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
ScheduleType - Enum in com.hazelcast.internal.util.scheduler
Controls behaviour of SecondsBasedEntryTaskScheduler when a new entry is added under already existing key.
scheduleWithRepetition(Runnable, long, TimeUnit) - Method in class com.hazelcast.client.cp.internal.session.ClientProxySessionManager
 
scheduleWithRepetition(Runnable, long) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheScheduler
 
scheduleWithRepetition(Runnable, long, long, TimeUnit) - Method in class com.hazelcast.client.impl.spi.impl.ClientExecutionServiceImpl
 
scheduleWithRepetition(Runnable, long, TimeUnit) - Method in class com.hazelcast.cp.internal.session.AbstractProxySessionManager
Schedules the given task for repeating execution
scheduleWithRepetition(Runnable, long, TimeUnit) - Method in class com.hazelcast.cp.internal.session.ProxySessionManagerService
 
scheduleWithRepetition(Runnable, long) - Method in interface com.hazelcast.map.impl.querycache.QueryCacheScheduler
Executes a task periodically with the supplied delaySeconds.
scheduleWithRepetition(Runnable, long) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheScheduler
 
scheduleWithRepetition(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
scheduleWithRepetition(String, Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
scheduleWithRepetition(Runnable, long, long, TimeUnit) - Method in class com.hazelcast.spi.impl.executionservice.impl.DelegatingTaskScheduler
 
scheduleWithRepetition(Runnable, long, long, TimeUnit) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
scheduleWithRepetition(String, Runnable, long, long, TimeUnit) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
scheduleWithRepetition(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.spi.impl.executionservice.TaskScheduler
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period.
schemaValidation(Document) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
SCRIPT_EXECUTOR - Static variable in class com.hazelcast.internal.management.ManagementDataSerializerHook
 
ScriptEngineManagerContext - Class in com.hazelcast.internal.management
Accessor for ScriptEngineManager
ScriptExecutorOperation - Class in com.hazelcast.internal.management.operation
Operation to execute script on the node.
ScriptExecutorOperation() - Constructor for class com.hazelcast.internal.management.operation.ScriptExecutorOperation
 
ScriptExecutorOperation(String, String) - Constructor for class com.hazelcast.internal.management.operation.ScriptExecutorOperation
 
SEARCH_DYNAMIC_CONFIG_FIRST - Static variable in class com.hazelcast.spi.properties.GroupProperty
By default, search for data structures config is performed within static configuration first: Exact match in static config Wildcard match in static config Exact match in dynamic config Wildcard match in dynamic config Fallback to default But sometimes it makes sense to perform search within dynamic configs first.
Searcher<T extends IdentifiedDataSerializable> - Interface in com.hazelcast.internal.dynamicconfig.search
Performs search data structures configuration based on selected search method
searcherFor(Config, ConfigurationService, ConfigPatternMatcher, boolean) - Static method in class com.hazelcast.internal.dynamicconfig.search.ConfigSearch
Factory method for creating Searcher instances
searchForOtherClusters() - Method in class com.hazelcast.internal.cluster.impl.MulticastJoiner
 
searchForOtherClusters() - Method in class com.hazelcast.internal.cluster.impl.TcpIpJoiner
 
searchForOtherClusters() - Method in interface com.hazelcast.internal.cluster.Joiner
 
SECOND_ENTRY_HAS_HIGHER_PRIORITY_TO_BE_EVICTED - Static variable in class com.hazelcast.internal.eviction.EvictionPolicyComparator
Integer constant for representing behaviour for giving higher priority to second entry to be evicted.
secondary() - Method in class com.hazelcast.client.impl.connection.Addresses
 
SecondsBasedEntryTaskScheduler<K,V> - Class in com.hazelcast.internal.util.scheduler
Schedule execution of an entry for seconds later.
SecureCallable<V> - Interface in com.hazelcast.security
A secure callable that runs in a sandbox.
SecureRequest - Interface in com.hazelcast.client.impl.client
 
SecureStore - Interface in com.hazelcast.spi.impl.securestore
A Secure Store abstraction for interacting with systems that manage symmetric encryption keys.
SecureStore.EncryptionKeyListener - Interface in com.hazelcast.spi.impl.securestore
Secure Store listener to get notified of changes to encryption keys.
SecureStoreConfig - Class in com.hazelcast.config
Abstract Secure Store configuration class.
SecureStoreConfig() - Constructor for class com.hazelcast.config.SecureStoreConfig
 
SecureStoreException - Exception in com.hazelcast.spi.impl.securestore
Exception class used to report run-time Secure Store related errors.
SecureStoreException(String) - Constructor for exception com.hazelcast.spi.impl.securestore.SecureStoreException
Creates a SecureStoreException with the given message.
SecureStoreException(String, Throwable) - Constructor for exception com.hazelcast.spi.impl.securestore.SecureStoreException
Creates a SecureStoreException with the given detail message and cause.
SecureStoreFactory - Interface in com.hazelcast.spi.impl.securestore
Factory to provide SecureStore implementations.
SECURITY - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
SecurityConfig - Class in com.hazelcast.config
Contains configuration for Security
SecurityConfig() - Constructor for class com.hazelcast.config.SecurityConfig
 
securityContext - Variable in class com.hazelcast.instance.impl.Node
 
SecurityContext - Interface in com.hazelcast.security
SecurityContext is responsible for managing lifecycle of security object such as ICredentialsFactory, IPermissionPolicy etc, to creating LoginContextes for member and client authentications and checking permissions for client operations.
SecurityInterceptor - Interface in com.hazelcast.security
This interface allows to intercept requests which were produced by an API call like map.put, queue.offer...
SecurityInterceptorConfig - Class in com.hazelcast.config
This class is used to configure SecurityInterceptor
SecurityInterceptorConfig() - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
 
SecurityInterceptorConfig(String) - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
 
SecurityInterceptorConfig(SecurityInterceptor) - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
 
SecurityService - Interface in com.hazelcast.security
Provides necessary methods to initiate security related config changes.
segment - Variable in class com.hazelcast.map.impl.iterator.AbstractMapQueryPartitionIterator
 
segments - Variable in class com.hazelcast.cache.impl.AbstractCacheService
 
select(Client) - Method in interface com.hazelcast.client.impl.ClientSelector
 
select(Member) - Method in class com.hazelcast.cluster.memberselector.impl.AndMemberSelector
 
select(Member) - Method in class com.hazelcast.cluster.memberselector.impl.OrMemberSelector
 
select(Member) - Method in interface com.hazelcast.cluster.MemberSelector
Decides if the given member will be part of an operation or not.
SELECT_NOW_STRING - Static variable in enum com.hazelcast.internal.networking.nio.SelectorMode
 
SELECT_STRING - Static variable in enum com.hazelcast.internal.networking.nio.SelectorMode
 
SELECT_WITH_FIX_STRING - Static variable in enum com.hazelcast.internal.networking.nio.SelectorMode
 
selectionKey - Variable in class com.hazelcast.internal.networking.nio.NioPipeline
 
selectorMode(SelectorMode) - Method in class com.hazelcast.internal.networking.nio.NioNetworking.Context
 
SelectorMode - Enum in com.hazelcast.internal.networking.nio
Controls the mode in which IO and acceptor thread selectors will be operating
SelectorOptimizer - Class in com.hazelcast.internal.networking.nio
The SelectorOptimizer optimizes the Selector so less litter is being created.
selectorWorkaroundTest(boolean) - Method in class com.hazelcast.internal.networking.nio.NioNetworking.Context
 
self() - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService.Builder
 
self() - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1.Builder
 
Semaphore - Class in com.hazelcast.cp.internal.datastructures.semaphore
State-machine implementation of the Raft-based semaphore.
SEMAPHORE_ENDPOINT - Static variable in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreDataSerializerHook
 
SEMAPHORE_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
SEMAPHORE_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
SemaphoreAcquireCodec - Class in com.hazelcast.client.impl.protocol.codec
Acquires the requested amount of permits if available, reducing the number of available permits.
SemaphoreAcquireCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SemaphoreAcquireCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SemaphoreAvailablePermitsCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the number of available permits.
SemaphoreAvailablePermitsCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SemaphoreAvailablePermitsCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SemaphoreChangeCodec - Class in com.hazelcast.client.impl.protocol.codec
Increases or decreases the number of permits by the given value.
SemaphoreChangeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SemaphoreChangeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SemaphoreConfig - Class in com.hazelcast.config.cp
Contains configuration options for CP ISemaphore
SemaphoreConfig() - Constructor for class com.hazelcast.config.cp.SemaphoreConfig
 
SemaphoreConfig(String) - Constructor for class com.hazelcast.config.cp.SemaphoreConfig
 
SemaphoreConfig(String, boolean) - Constructor for class com.hazelcast.config.cp.SemaphoreConfig
 
SemaphoreDataSerializerHook - Class in com.hazelcast.cp.internal.datastructures.semaphore
 
SemaphoreDataSerializerHook() - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreDataSerializerHook
 
SemaphoreDrainCodec - Class in com.hazelcast.client.impl.protocol.codec
Acquires all available permits at once and returns immediately.
SemaphoreDrainCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SemaphoreDrainCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SemaphoreEndpoint - Class in com.hazelcast.cp.internal.datastructures.semaphore
SemaphoreEndpoint represents a thread in a Raft client.
SemaphoreEndpoint() - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreEndpoint
 
SemaphoreEndpoint(long, long) - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreEndpoint
 
SemaphoreGetSemaphoreTypeCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns true if the semaphore is JDK compatible
SemaphoreGetSemaphoreTypeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SemaphoreGetSemaphoreTypeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SemaphoreInitCodec - Class in com.hazelcast.client.impl.protocol.codec
Initializes the ISemaphore instance with the given permit number, if not initialized before.
SemaphoreInitCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SemaphoreInitCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SemaphoreMBean - Class in com.hazelcast.internal.jmx
Management bean for ISemaphore
SemaphoreMBean(ISemaphore, ManagementService) - Constructor for class com.hazelcast.internal.jmx.SemaphoreMBean
 
SemaphorePermission - Class in com.hazelcast.security.permission
 
SemaphorePermission(String, String...) - Constructor for class com.hazelcast.security.permission.SemaphorePermission
 
SemaphoreRegistry - Class in com.hazelcast.cp.internal.datastructures.semaphore
Contains Semaphore resources and manages wait timeouts based on acquire / release requests
SemaphoreReleaseCodec - Class in com.hazelcast.client.impl.protocol.codec
Releases the given number of permits and increases the number of available permits by that amount.
SemaphoreReleaseCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SemaphoreReleaseCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SemaphoreService - Class in com.hazelcast.cp.internal.datastructures.semaphore
Contains Raft-based semaphore instances
SemaphoreService(NodeEngine) - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreService
 
send(ClientInvocation, ClientConnection) - Method in class com.hazelcast.client.impl.spi.impl.AbstractClientInvocationService
 
send(PreVoteRequest, RaftEndpoint) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Sends the given PreVoteRequest DTO to target endpoint to be handled by via RaftNode.handlePreVoteRequest(PreVoteRequest).
send(PreVoteResponse, RaftEndpoint) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Sends the given PreVoteResponse DTO to target endpoint to be handled via RaftNode.handlePreVoteResponse(PreVoteResponse).
send(VoteRequest, RaftEndpoint) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Sends the given VoteRequest DTO to target endpoint to be handled via RaftNode.handleVoteRequest(VoteRequest).
send(VoteResponse, RaftEndpoint) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Sends the given VoteResponse DTO to target endpoint to be handled via RaftNode.handleVoteResponse(VoteResponse).
send(AppendRequest, RaftEndpoint) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Sends the given AppendRequest DTO to target endpoint to be handled via RaftNode.handleAppendRequest(AppendRequest).
send(AppendSuccessResponse, RaftEndpoint) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Sends the given AppendSuccessResponse DTO to target endpoint to be handled via RaftNode.handleAppendResponse(AppendSuccessResponse).
send(AppendFailureResponse, RaftEndpoint) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Sends the given AppendFailureResponse DTO to target endpoint to be handled via RaftNode.handleAppendResponse(AppendFailureResponse).
send(InstallSnapshot, RaftEndpoint) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Sends the given InstallSnapshot DTO to target endpoint to be handled via RaftNode.handleInstallSnapshot(InstallSnapshot).
send(TriggerLeaderElection, RaftEndpoint) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Sends the given TriggerLeaderElection DTO to target endpoint to be handled via RaftNode.handleTriggerLeaderElection(TriggerLeaderElection).
send(PreVoteRequest, RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
send(PreVoteResponse, RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
send(VoteRequest, RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
send(VoteResponse, RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
send(AppendSuccessResponse, RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
send(AppendFailureResponse, RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
send(TriggerLeaderElection, RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
send(JoinMessage) - Method in class com.hazelcast.internal.cluster.impl.MulticastService
 
send(Address, Operation) - Method in class com.hazelcast.internal.management.ManagementCenterService
 
send() - Method in class com.hazelcast.internal.nio.tcp.BindRequest
 
send(Operation, Address) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
send(Operation, Address) - Method in class com.hazelcast.spi.impl.operationservice.impl.OutboundOperationHandler
 
send(Operation, Connection) - Method in class com.hazelcast.spi.impl.operationservice.impl.OutboundOperationHandler
 
send(EndpointManager, Address, Response) - Method in class com.hazelcast.spi.impl.operationservice.impl.OutboundResponseHandler
 
send(Operation, Address) - Method in interface com.hazelcast.spi.impl.operationservice.OperationService
Executes an operation remotely.
send200() - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
 
send204() - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
 
send400() - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
 
send403() - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
 
send404() - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
 
send500() - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
 
SEND_EVENT - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
sendAppendRequest(RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Sends an append-entries request to the follower member.
sendBackupAck(EndpointManager, Address, long, boolean) - Method in class com.hazelcast.spi.impl.operationservice.impl.OutboundResponseHandler
 
sendClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
sendClientMessage(Object, ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
sendEndOfSequenceEvents(PublisherContext, int) - Static method in class com.hazelcast.map.impl.querycache.publisher.AccumulatorSweeper
 
sender() - Method in class com.hazelcast.cp.internal.raft.impl.handler.AbstractResponseHandlerTask
 
sender() - Method in class com.hazelcast.cp.internal.raft.impl.handler.AppendFailureResponseHandlerTask
 
sender() - Method in class com.hazelcast.cp.internal.raft.impl.handler.AppendSuccessResponseHandlerTask
 
sender() - Method in class com.hazelcast.cp.internal.raft.impl.handler.PreVoteResponseHandlerTask
 
sender() - Method in class com.hazelcast.cp.internal.raft.impl.handler.VoteResponseHandlerTask
 
SendEventOperation - Class in com.hazelcast.spi.impl.eventservice.impl.operations
An operation for sending a event to a remote subscriber (not on this node).
SendEventOperation() - Constructor for class com.hazelcast.spi.impl.eventservice.impl.operations.SendEventOperation
 
SendEventOperation(EventEnvelope, int) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.operations.SendEventOperation
 
sendEventToSubscriber(String, Object, int) - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheEventService
 
sendEventToSubscriber(String, Object, int) - Method in interface com.hazelcast.map.impl.querycache.QueryCacheEventService
Only sends events which wrap data to be put in a query cache.
sendEventToSubscriber(String, Object, int) - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheEventService
 
sendImmediately(Invalidation, int) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
 
sendInvalidation(Invalidation) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.AbstractBaseNearCacheInvalidationListener
 
sendInvalidationEvent(String, Data, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheService
Sends an invalidation event for given cacheName with specified key from mentioned source with sourceUuid.
sendInvalidationEvent(String, Data, UUID) - Method in interface com.hazelcast.cache.impl.ICacheService
 
sendJoinRequest(Address, boolean) - Method in class com.hazelcast.internal.cluster.impl.ClusterJoinManager
Send join request to toAddress.
sendLocalMembershipEvent() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
sendMasterQuestion(Address) - Method in class com.hazelcast.internal.cluster.impl.ClusterJoinManager
Send a WhoisMasterOp to designated address.
sendMemberListToMember(Address) - Method in class com.hazelcast.internal.cluster.impl.MembershipManager
Sends the current member list to the target.
sendMessageWithOrderKey(ClientMessage, Object) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.AbstractBaseNearCacheInvalidationListener
 
sendMigrationEvent(MigrationState, MigrationInfo, long) - Method in class com.hazelcast.internal.partition.impl.PartitionEventManager
Sends a ReplicaMigrationEvent to the registered event listeners.
sendMigrationProcessCompletedEvent(MigrationState) - Method in class com.hazelcast.internal.partition.impl.PartitionEventManager
 
sendMigrationProcessStartedEvent(MigrationState) - Method in class com.hazelcast.internal.partition.impl.PartitionEventManager
 
sendNotification(Notification) - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
 
sendPartitionLostEvent(int, int) - Method in class com.hazelcast.internal.partition.impl.PartitionEventManager
 
sendPhoneHome() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
sendPhoneHome() - Method in interface com.hazelcast.instance.impl.NodeExtension
Send PhoneHome ping from OS or EE instance to PhoneHome application
sendQueuedExpiredKeys(T) - Method in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
sendReplicationOperation(boolean) - Method in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
 
sendResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
sendResponse(HttpPostCommand, String) - Method in class com.hazelcast.internal.ascii.rest.HttpPostCommandProcessor
 
sendResponse(TextCommand) - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
sendResponse(TextCommand) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
sendResponse(TextCommand) - Method in class com.hazelcast.internal.nio.ascii.TextDecoder
 
sendResponse(Operation, Object) - Method in class com.hazelcast.internal.util.LocalRetryableExecution
 
sendResponse(Operation, Object) - Method in class com.hazelcast.spi.impl.operationservice.impl.Invocation
 
sendResponse(Operation, Object) - Method in class com.hazelcast.spi.impl.operationservice.impl.OutboundResponseHandler
 
sendResponse(Object) - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
sendResponse(O, Object) - Method in interface com.hazelcast.spi.impl.operationservice.OperationResponseHandler
Sends a response.
sendSplitBrainJoinMessageAndCheckResponse(Address, SplitBrainJoinMessage) - Method in class com.hazelcast.internal.cluster.impl.AbstractJoiner
Sends a split brain join request to the target address and checks the response to see if this node should merge to the target address.
sendUpdateCallerOperation(boolean) - Method in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
 
sequence - Variable in class com.hazelcast.client.impl.protocol.codec.ContinuousQuerySetReadCursorCodec.RequestParameters
The cursor position of the accumulator to be set.
sequence - Variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorDisposeResultCodec.RequestParameters
Sequence of the execution.
sequence - Variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveAndDisposeResultCodec.RequestParameters
Sequence of the execution.
sequence - Variable in class com.hazelcast.client.impl.protocol.codec.DurableExecutorRetrieveResultCodec.RequestParameters
Sequence of the execution.
sequence - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferReadOneCodec.RequestParameters
the sequence of the item to read.
sequence - Variable in class com.hazelcast.internal.journal.EventJournalReadOperation
 
sequence - Variable in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
Sequence(long, boolean) - Constructor for class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore.Sequence
 
sequence - Variable in class com.hazelcast.topic.impl.reliable.MessageRunner
 
SEQUENCE_UNAVAILABLE - Static variable in interface com.hazelcast.ringbuffer.ReadResultSet
Value returned from methods returning a sequence number when the information is not available (e.g.
Sequenced - Interface in com.hazelcast.map.impl.querycache.event.sequence
This interface should be implemented by events which need a sequence number.
SerializableByConvention - Annotation Type in com.hazelcast.internal.serialization
Indicates that the annotated class cannot be converted to IdentifiedDataSerializable due to other conventions.
SerializableByConvention.Reason - Enum in com.hazelcast.internal.serialization
 
SerializableList - Class in com.hazelcast.spi.impl
 
SerializableList() - Constructor for class com.hazelcast.spi.impl.SerializableList
 
SerializableList(List<Data>) - Constructor for class com.hazelcast.spi.impl.SerializableList
 
SerializableXID - Class in com.hazelcast.transaction.impl.xa
 
SerializableXID() - Constructor for class com.hazelcast.transaction.impl.xa.SerializableXID
 
SerializableXID(int, byte[], byte[]) - Constructor for class com.hazelcast.transaction.impl.xa.SerializableXID
 
SERIALIZATION_VERSION - Static variable in class com.hazelcast.instance.GeneratedBuildProperties
 
SERIALIZATION_VERSION - Static variable in class com.hazelcast.spi.properties.GroupProperty
Hazelcast serialization version.
SerializationClassNameFilter - Class in com.hazelcast.internal.serialization
Implementation of basic protection against untrusted deserialization.
SerializationClassNameFilter(JavaSerializationFilterConfig) - Constructor for class com.hazelcast.internal.serialization.SerializationClassNameFilter
 
SerializationConfig - Class in com.hazelcast.config
Contains the serialization configuration of HazelcastInstance.
SerializationConfig() - Constructor for class com.hazelcast.config.SerializationConfig
 
SerializationConfig(SerializationConfig) - Constructor for class com.hazelcast.config.SerializationConfig
 
SerializationConstants - Class in com.hazelcast.internal.serialization.impl
 
serializationService - Variable in class com.hazelcast.cache.impl.CacheRecordStore
 
serializationService - Variable in class com.hazelcast.cache.impl.record.CacheRecordFactory
 
serializationService - Variable in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
 
serializationService - Variable in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
serializationService - Variable in class com.hazelcast.collection.impl.collection.CollectionService
 
serializationService - Variable in class com.hazelcast.config.AbstractCacheConfig
 
serializationService - Variable in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
serializationService - Variable in class com.hazelcast.internal.nearcache.impl.DefaultNearCacheManager
 
serializationService - Variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
serializationService - Variable in class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolImpl
 
SerializationService - Interface in com.hazelcast.internal.serialization
SPI to serialize user objects to Data and back to Object Data is the internal representation of binary data in hazelcast.
serializationService - Variable in class com.hazelcast.map.impl.event.AbstractFilteringStrategy
 
serializationService - Variable in class com.hazelcast.map.impl.event.MapEventPublisherImpl
 
serializationService - Variable in class com.hazelcast.map.impl.MapContainer
 
serializationService - Variable in class com.hazelcast.map.impl.query.PartitionScanRunner
 
serializationService - Variable in class com.hazelcast.map.impl.query.QueryRunner
 
serializationService - Variable in class com.hazelcast.query.impl.QueryableEntry
 
serializationService - Variable in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
serializationService - Variable in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
 
serializationService - Variable in class com.hazelcast.spi.impl.operationservice.Offload
 
SerializationServiceAware - Interface in com.hazelcast.internal.serialization
Used to get a SerializationService reference injected.
SerializationServiceBuilder - Interface in com.hazelcast.internal.serialization
 
SerializationServiceSupport - Interface in com.hazelcast.spi.impl
 
SerializationServiceV1 - Class in com.hazelcast.internal.serialization.impl
 
SerializationServiceV1.AbstractBuilder<T extends SerializationServiceV1.AbstractBuilder<T>> - Class in com.hazelcast.internal.serialization.impl
 
SerializationServiceV1.Builder - Class in com.hazelcast.internal.serialization.impl
 
SerializationUtil - Class in com.hazelcast.internal.serialization.impl
 
serializationVersion - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec.RequestParameters
client side supported version to inform server side
serializationVersion - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec.ResponseParameters
client side supported version to inform server side
serializationVersion - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec.RequestParameters
client side supported version to inform server side
serializationVersion - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec.ResponseParameters
client side supported version to inform server side
serializer - Variable in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
 
Serializer - Interface in com.hazelcast.nio.serialization
Base interface of custom serialization interfaces
SerializerConfig - Class in com.hazelcast.config
Contains the serialization configuration for a particular class.
SerializerConfig() - Constructor for class com.hazelcast.config.SerializerConfig
 
SerializerConfig(SerializerConfig) - Constructor for class com.hazelcast.config.SerializerConfig
 
serializerFor(int) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
serializerFor(Object) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
SerializerHook<T> - Interface in com.hazelcast.nio.serialization
This interface is used to automatically register serializers from external Hazelcast or user modules.
Both types of Serializers are supported (StreamSerializer and ByteArraySerializer).
SERVER_ERROR - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
 
serverHazelcastVersion - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec.ResponseParameters
TODO DOC
serverHazelcastVersion - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec.ResponseParameters
TODO DOC
ServerSocketEndpointConfig - Class in com.hazelcast.config
Endpoint configuration that defines a listening side (server)
ServerSocketEndpointConfig() - Constructor for class com.hazelcast.config.ServerSocketEndpointConfig
 
ServerSocketRegistry - Class in com.hazelcast.internal.networking
Registry that holds all initiated ServerSocket when advanced-networking is in-use Or holds a single universal ServerSocket when plain old networking is in-use.
ServerSocketRegistry(Map<EndpointQualifier, ServerSocketChannel>, boolean) - Constructor for class com.hazelcast.internal.networking.ServerSocketRegistry
 
ServerSocketRegistry.Pair - Class in com.hazelcast.internal.networking
 
SERVICE_NAME - Static variable in interface com.hazelcast.cache.impl.ICacheService
 
SERVICE_NAME - Static variable in class com.hazelcast.cardinality.impl.CardinalityEstimatorService
 
SERVICE_NAME - Static variable in class com.hazelcast.client.impl.ClientEngineImpl
Service name to be used in requests.
SERVICE_NAME - Static variable in class com.hazelcast.collection.impl.list.ListService
 
SERVICE_NAME - Static variable in class com.hazelcast.collection.impl.queue.QueueService
 
SERVICE_NAME - Static variable in class com.hazelcast.collection.impl.set.SetService
 
SERVICE_NAME - Static variable in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongService
Name of the service
SERVICE_NAME - Static variable in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefService
Name of the service
SERVICE_NAME - Static variable in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchService
Name of the service
SERVICE_NAME - Static variable in class com.hazelcast.cp.internal.datastructures.lock.LockService
Name of the service
SERVICE_NAME - Static variable in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreService
Name of the service
SERVICE_NAME - Static variable in class com.hazelcast.cp.internal.RaftService
 
SERVICE_NAME - Static variable in class com.hazelcast.cp.internal.session.ProxySessionManagerService
Name of the service
SERVICE_NAME - Static variable in class com.hazelcast.cp.internal.session.RaftSessionService
 
SERVICE_NAME - Static variable in class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
 
SERVICE_NAME - Static variable in class com.hazelcast.executor.impl.DistributedExecutorService
 
SERVICE_NAME - Static variable in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorService
 
SERVICE_NAME - Static variable in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
SERVICE_NAME - Static variable in class com.hazelcast.internal.crdt.CRDTReplicationMigrationService
The name of this service
SERVICE_NAME - Static variable in class com.hazelcast.internal.crdt.pncounter.PNCounterService
The name under which this service is registered
SERVICE_NAME - Static variable in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
SERVICE_NAME - Static variable in interface com.hazelcast.internal.locksupport.LockSupportService
 
SERVICE_NAME - Static variable in class com.hazelcast.internal.longregister.LongRegisterService
Keeping the old service name for backward compatibility during performance testing.
SERVICE_NAME - Static variable in class com.hazelcast.internal.metrics.impl.MetricsService
 
SERVICE_NAME - Static variable in class com.hazelcast.internal.usercodedeployment.UserCodeDeploymentService
 
SERVICE_NAME - Static variable in class com.hazelcast.map.impl.MapService
 
SERVICE_NAME - Static variable in class com.hazelcast.multimap.impl.MultiMapService
 
SERVICE_NAME - Static variable in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
SERVICE_NAME - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferService
The ringbuffer service name which defines it in the node engine.
SERVICE_NAME - Static variable in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
SERVICE_NAME - Static variable in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
SERVICE_NAME - Static variable in interface com.hazelcast.spi.impl.operationparker.OperationParker
 
SERVICE_NAME - Static variable in interface com.hazelcast.spi.impl.operationservice.OperationService
 
SERVICE_NAME - Static variable in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
 
SERVICE_NAME - Static variable in interface com.hazelcast.spi.partition.IPartitionService
The name of the service.
SERVICE_NAME - Static variable in class com.hazelcast.splitbrainprotection.impl.SplitBrainProtectionServiceImpl
 
SERVICE_NAME - Static variable in class com.hazelcast.topic.impl.reliable.ReliableTopicService
 
SERVICE_NAME - Static variable in class com.hazelcast.topic.impl.TopicService
 
SERVICE_NAME - Static variable in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
SERVICE_NAME - Static variable in class com.hazelcast.transaction.impl.xa.XAService
 
SERVICE_NAME - Static variable in interface com.hazelcast.wan.impl.WanReplicationService
Service name.
SERVICE_NOT_FOUND - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
ServiceConfig - Class in com.hazelcast.config
Configuration for a single service.
ServiceConfig() - Constructor for class com.hazelcast.config.ServiceConfig
 
ServiceConfigurationParser<T> - Interface in com.hazelcast.internal.services
A hook into the parsing system.
ServiceDescriptor - Interface in com.hazelcast.spi.impl.servicemanager
Descriptor of Hazelcast managed service;
ServiceDescriptorProvider - Interface in com.hazelcast.spi.impl.servicemanager
Provides information about services.
ServiceInfo - Class in com.hazelcast.spi.impl.servicemanager
Contains the name of the service and the actual service.
ServiceInfo(String, Object) - Constructor for class com.hazelcast.spi.impl.servicemanager.ServiceInfo
 
ServiceLoader - Class in com.hazelcast.internal.util
Support class for loading Hazelcast services and hooks based on the Java ServiceLoader specification, but changed to the fact of class loaders to test for given services to work in multi classloader environments like application or OSGi servers.
ServiceManager - Interface in com.hazelcast.spi.impl.servicemanager
Responsible for managing services.
ServiceManagerImpl - Class in com.hazelcast.spi.impl.servicemanager.impl
 
ServiceManagerImpl(NodeEngineImpl) - Constructor for class com.hazelcast.spi.impl.servicemanager.impl.ServiceManagerImpl
 
serviceName - Variable in class com.hazelcast.client.impl.protocol.codec.ClientCreateProxyCodec.RequestParameters
The name of the service.
serviceName - Variable in class com.hazelcast.client.impl.protocol.codec.ClientDestroyProxyCodec.RequestParameters
The name of the service.
serviceName - Variable in class com.hazelcast.client.impl.protocol.codec.CPGroupDestroyCPObjectCodec.RequestParameters
The service of this distributed object
serviceName - Variable in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
 
serviceName() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchService
 
serviceName() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockService
 
serviceName() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreService
 
serviceName() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
Returns name of the service.
serviceName - Variable in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
 
serviceName - Variable in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
 
ServiceNamespace - Interface in com.hazelcast.internal.services
ServiceNamespace is a namespace to group objects, structures, fragments within a service.
ServiceNamespaceAware - Interface in com.hazelcast.internal.services
An object which is aware of ServiceNamespace which object itself belongs to.
ServiceNotFoundException - Exception in com.hazelcast.spi.exception
A HazelcastException that indicates that a requested service is not exist.
ServiceNotFoundException(String) - Constructor for exception com.hazelcast.spi.exception.ServiceNotFoundException
 
ServicesConfig - Class in com.hazelcast.config
Configuration for the Services.
ServicesConfig() - Constructor for class com.hazelcast.config.ServicesConfig
 
SESSION_EXPIRED_EXCEPTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
SESSION_RESPONSE - Static variable in class com.hazelcast.cp.internal.session.RaftSessionServiceDataSerializerHook
 
SessionAccessor - Interface in com.hazelcast.cp.internal.session
Used by services to validate and trigger session activity
SessionAwareProxy - Class in com.hazelcast.cp.internal.session
Base class for server and client proxies that make use of Raft sessions
SessionAwareProxy(AbstractProxySessionManager, RaftGroupId) - Constructor for class com.hazelcast.cp.internal.session.SessionAwareProxy
 
SessionAwareSemaphoreProxy - Class in com.hazelcast.client.cp.internal.datastructures.semaphore
Client-side session-aware proxy of Raft-based ISemaphore
SessionAwareSemaphoreProxy(ClientContext, RaftGroupId, String, String) - Constructor for class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionAwareSemaphoreProxy
 
SessionAwareSemaphoreProxy - Class in com.hazelcast.cp.internal.datastructures.semaphore.proxy
Server-side session-aware proxy of Raft-based ISemaphore
SessionAwareSemaphoreProxy(NodeEngine, RaftGroupId, String, String) - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionAwareSemaphoreProxy
 
SessionAwareService - Interface in com.hazelcast.cp.internal.session
Services that attach their resources to Raft sessions implement this service
SessionExpiredException - Exception in com.hazelcast.cp.internal.session
Thrown when an operation is attached to a Raft session is no longer active
SessionExpiredException() - Constructor for exception com.hazelcast.cp.internal.session.SessionExpiredException
 
SessionExpiredException(String) - Constructor for exception com.hazelcast.cp.internal.session.SessionExpiredException
 
SessionExpiredException(String, Throwable) - Constructor for exception com.hazelcast.cp.internal.session.SessionExpiredException
 
sessionId - Variable in class com.hazelcast.client.impl.protocol.codec.CPSessionCloseSessionCodec.RequestParameters
ID of the session
sessionId - Variable in class com.hazelcast.client.impl.protocol.codec.CPSessionCreateSessionCodec.ResponseParameters
TODO DOC
sessionId - Variable in class com.hazelcast.client.impl.protocol.codec.CPSessionHeartbeatSessionCodec.RequestParameters
ID of the session
sessionId - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockGetLockOwnershipCodec.ResponseParameters
TODO DOC
sessionId - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockLockCodec.RequestParameters
Session ID of the caller
sessionId - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockTryLockCodec.RequestParameters
Session ID of the caller
sessionId - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockUnlockCodec.RequestParameters
Session ID of the caller
sessionId - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreAcquireCodec.RequestParameters
Session ID of the caller
sessionId - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreChangeCodec.RequestParameters
Session ID of the caller
sessionId - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreDrainCodec.RequestParameters
Session ID of the caller
sessionId - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreReleaseCodec.RequestParameters
Session ID of the caller
sessionId() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.AwaitInvocationKey
 
sessionId() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockEndpoint
 
sessionId() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockInvocationKey
 
sessionId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.AcquireInvocationKey
 
sessionId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreEndpoint
 
sessionId() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKey
Returns id of the session to which the corresponding operation is attached.
sessionId() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKeyContainer
 
SessionlessSemaphoreProxy - Class in com.hazelcast.client.cp.internal.datastructures.semaphore
Client-side sessionless proxy of Raft-based ISemaphore
SessionlessSemaphoreProxy(ClientContext, RaftGroupId, String, String) - Constructor for class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionlessSemaphoreProxy
 
SessionlessSemaphoreProxy - Class in com.hazelcast.cp.internal.datastructures.semaphore.proxy
Server-side sessionless proxy of Raft-based ISemaphore
SessionlessSemaphoreProxy(NodeEngine, RaftGroupId, String, String) - Constructor for class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionlessSemaphoreProxy
 
SessionResponse - Class in com.hazelcast.cp.internal.session
Represents information of a session that is just created.
SessionResponse(long, long, long) - Constructor for class com.hazelcast.cp.internal.session.SessionResponse
 
set(long) - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
set(T) - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
set(int, E) - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
set(K, V, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
set(K, V, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
set(K, V) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
set(K, V) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
set(int, long, Data) - Method in class com.hazelcast.collection.impl.list.ListContainer
 
set(int, E) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
 
set(long) - Method in interface com.hazelcast.cp.IAtomicLong
Atomically sets the given value.
set(E) - Method in interface com.hazelcast.cp.IAtomicReference
Atomically sets the given value.
set(long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
set(Data) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRef
 
set(T) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
set(K, V) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
set(K, V) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
set(K, V) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
set(K, V) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
set(K, V) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
set(long) - Method in class com.hazelcast.internal.jmx.AtomicLongMBean
 
set(int, int) - Method in class com.hazelcast.internal.json.JsonArray
Replaces the element at the specified position in this array with the JSON representation of the specified int value.
set(int, long) - Method in class com.hazelcast.internal.json.JsonArray
Replaces the element at the specified position in this array with the JSON representation of the specified long value.
set(int, float) - Method in class com.hazelcast.internal.json.JsonArray
Replaces the element at the specified position in this array with the JSON representation of the specified float value.
set(int, double) - Method in class com.hazelcast.internal.json.JsonArray
Replaces the element at the specified position in this array with the JSON representation of the specified double value.
set(int, boolean) - Method in class com.hazelcast.internal.json.JsonArray
Replaces the element at the specified position in this array with the JSON representation of the specified boolean value.
set(int, String) - Method in class com.hazelcast.internal.json.JsonArray
Replaces the element at the specified position in this array with the JSON representation of the specified string.
set(int, JsonValue) - Method in class com.hazelcast.internal.json.JsonArray
Replaces the element at the specified position in this array with the specified JSON value.
set(String, int) - Method in class com.hazelcast.internal.json.JsonObject
Sets the value of the member with the specified name to the JSON representation of the specified int value.
set(String, long) - Method in class com.hazelcast.internal.json.JsonObject
Sets the value of the member with the specified name to the JSON representation of the specified long value.
set(String, float) - Method in class com.hazelcast.internal.json.JsonObject
Sets the value of the member with the specified name to the JSON representation of the specified float value.
set(String, double) - Method in class com.hazelcast.internal.json.JsonObject
Sets the value of the member with the specified name to the JSON representation of the specified double value.
set(String, boolean) - Method in class com.hazelcast.internal.json.JsonObject
Sets the value of the member with the specified name to the JSON representation of the specified boolean value.
set(String, String) - Method in class com.hazelcast.internal.json.JsonObject
Sets the value of the member with the specified name to the JSON representation of the specified string.
set(String, JsonValue) - Method in class com.hazelcast.internal.json.JsonObject
Sets the value of the member with the specified name to the specified JSON value.
set(long) - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
set(long) - Method in class com.hazelcast.internal.longregister.LongRegister
 
set(long) - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
set(T, long) - Method in class com.hazelcast.internal.util.ItemCounter
Set counter of item to value
set(E) - Method in class com.hazelcast.internal.util.UnmodifiableListIterator
 
set(K, V) - Method in interface com.hazelcast.map.BaseMap
Associates the specified value with the specified key in this map.
set(K, V) - Method in interface com.hazelcast.map.IMap
Puts an entry into this map without returning the old value (which is more efficient than put()).
set(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Puts an entry into this map with a given TTL (time to live) value, without returning the old value (which is more efficient than put()).
set(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Puts an entry into this map with a given TTL (time to live) value and max idle time value without returning the old value (which is more efficient than put()).
SET - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
set(K, V) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
set(K, V, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
set(K, V, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
set(K, V, EntryEventType) - Method in interface com.hazelcast.map.impl.querycache.subscriber.InternalQueryCache
 
set(Object, Object, EntryEventType) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
set(Data, Object, long, long) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
set(Data, Object, long, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
set(Object, Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
SET - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
set(long, E) - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
 
set(long, E) - Method in interface com.hazelcast.ringbuffer.impl.Ringbuffer
Sets the item at the given sequence.
set(long, T) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
Sets the item at the given sequence ID and updates the expiration time if TTL is configured.
set(long, Object) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Sets the item at the given sequence.
set(K, V) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.set(Object, Object).
SET_ALL_LISTENER_FLAGS - Static variable in class com.hazelcast.map.impl.MapListenerFlagOperator
Sets all listener flags.
SET_BACKUP - Static variable in class com.hazelcast.internal.longregister.LongRegisterDataSerializerHook
 
SET_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
SET_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SET_CONTAINER - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
SET_EXPIRY_POLICY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
SET_EXPIRY_POLICY_BACKUP - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
SET_LICENSE - Static variable in class com.hazelcast.internal.management.ManagementDataSerializerHook
 
SET_OP - Static variable in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefDataSerializerHook
 
SET_OPERATION - Static variable in class com.hazelcast.internal.longregister.LongRegisterDataSerializerHook
 
SET_READ_CURSOR - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
SET_REPLICATION - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
SET_TTL - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
SET_TTL_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
SET_WITH_EXPIRY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
setAccessHit(long) - Method in class com.hazelcast.cache.impl.CacheEventContext
 
setAccessHit(int) - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
setAccessHit(int) - Method in interface com.hazelcast.cache.impl.record.CacheRecord
Sets the access hit count of this Evictable.
setAccessHit(int) - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
setAccessHit(int) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecord
Sets the access hit count of this Evictable.
setAccessKey(String) - Method in class com.hazelcast.config.AwsConfig
setAccessTime(long) - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
setAccessTime(long) - Method in interface com.hazelcast.cache.impl.record.CacheRecord
Sets the access time of this Evictable in milliseconds.
setAccessTime(long) - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
setAccessTime(long) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecord
Sets the access time of this Evictable in milliseconds.
setAccessTime(long) - Method in interface com.hazelcast.map.impl.querycache.subscriber.record.QueryCacheRecord
Sets the access time of this Evictable in milliseconds.
setAcknowledgeType(WanAcknowledgeType) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the strategy for when the target cluster should acknowledge that a WAN event batch has been processed.
setAcquiresResource(boolean) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
setActions(Set<String>) - Method in class com.hazelcast.config.PermissionConfig
 
setActiveMigration(MigrationInfo) - Method in class com.hazelcast.internal.partition.impl.MigrationManager
Sets the active migration if none is set and returns null, otherwise returns the currently set active migration.
setActiveMigration(MigrationInfo) - Method in class com.hazelcast.internal.partition.PartitionRuntimeState
 
setActivePartitionCount(int) - Method in class com.hazelcast.internal.management.dto.PartitionServiceBeanDTO
 
SetAddAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds all of the elements in the specified collection to this set if they're not already present (optional operation).
SetAddAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetAddAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetAddAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
SetAddAllMessageTask
SetAddAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetAddAllMessageTask
 
SetAddCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds the specified element to this set if it is not already present (optional operation).
SetAddCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetAddCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetAddListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds an item listener for this collection.
SetAddListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
SetAddListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetAddListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetAddListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
SetAddListenerMessageTask
SetAddListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetAddListenerMessageTask
 
SetAddMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
SetAddMessageTask
SetAddMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetAddMessageTask
 
setAddress(String) - Method in class com.hazelcast.config.VaultSecureStoreConfig
Sets the Vault server address.
setAddress(String[]) - Method in class com.hazelcast.internal.util.AddressUtil.AddressMatcher
 
setAddress(long) - Method in class com.hazelcast.internal.util.hashslot.impl.SlotAssignmentResultImpl
Sets the current slot assignment address.
setAddress(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
setAddress(ScheduledTaskHandler, Address) - Static method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerAccessor
 
setAddresses(List<String>) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets given addresses as candidate address list that client will use to establish initial connection
setAdvancedNetworkConfig(AdvancedNetworkConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setAdvancedNetworkConfig(AdvancedNetworkConfig) - Method in class com.hazelcast.config.Config
 
setAdvancedNetworkConfig(AdvancedNetworkConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setAlgorithm(String) - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
Sets the encryption algorithm, such as AES/CBC/PKCS5Padding.
setAliasedDiscoveryConfigs(List<DiscoveryStrategyConfig>) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setAllFrom(OnDemandIndexStats) - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
Sets all the values in this stats to the corresponding values in the given on-demand stats.
setAllocatorType(NativeMemoryConfig.MemoryAllocatorType) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets the NativeMemoryConfig.MemoryAllocatorType to be used while allocating native memory.
setAllowUnsafe(boolean) - Method in class com.hazelcast.config.SerializationConfig
Unsafe, it is not public api of java.
setAllowUnsafe(boolean) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
setAllowUnsafe(boolean) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
setAnchor(int, Map.Entry) - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
After each query, an anchor entry is set for that page.
setAnchor(PagingPredicate, int, Map.Entry) - Static method in class com.hazelcast.query.PagingPredicateAccessor
 
setAndGetListenerFlags(ListenerAdapter) - Static method in class com.hazelcast.map.impl.MapListenerFlagOperator
Sets and gets flags of implemented listener interfaces of a MapListener.
setAppendRequestBackoff() - Method in class com.hazelcast.cp.internal.raft.impl.state.FollowerState
Sets the flag for append request backoff.
setAppendRequestBackoffTimeoutInMillis(long) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setAppendRequestMaxEntryCount(int) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setApplicationContext(ApplicationContext) - Method in class com.hazelcast.spring.context.SpringManagedContext
 
setAsync(long) - Method in class com.hazelcast.client.cp.internal.datastructures.atomiclong.AtomicLongProxy
 
setAsync(T) - Method in class com.hazelcast.client.cp.internal.datastructures.atomicref.AtomicRefProxy
 
setAsync(K, V) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
setAsync(K, V, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
setAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
setAsync(long) - Method in interface com.hazelcast.cp.IAtomicLong
Atomically sets the given value.
setAsync(E) - Method in interface com.hazelcast.cp.IAtomicReference
Atomically sets the given value.
setAsync(long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.proxy.AtomicLongProxy
 
setAsync(T) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.proxy.AtomicRefProxy
 
setAsync(K, V) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
setAsync(K, V, long, TimeUnit) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
setAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
setAsync(K, V) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
setAsync(K, V, long, TimeUnit) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
setAsync(K, V, ExpiryPolicy) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
setAsync(K, V) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
setAsync(K, V, long, TimeUnit) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
setAsync(K, V, ExpiryPolicy) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
setAsync(K, V) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
setAsync(K, V, long, TimeUnit) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
setAsync(K, V, ExpiryPolicy) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
setAsync(K, V) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
setAsync(K, V, long, TimeUnit) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
setAsync(K, V, ExpiryPolicy) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
setAsync(long) - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
setAsync(long) - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
setAsync(K, V) - Method in interface com.hazelcast.map.IMap
Asynchronously puts the given key and value.
setAsync(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Asynchronously puts an entry into this map with a given TTL (time to live) value, without returning the old value (which is more efficient than put()).
setAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Asynchronously puts an entry into this map with a given TTL (time to live) value and max idle time value without returning the old value (which is more efficient than put()).
setAsync(K, V) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
setAsync(K, V, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
setAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
setAsyncBackup(boolean) - Method in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheConfig
Sets the number of asynchronous backups for this ICache.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the number of asynchronous backups for this ICache.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Sets the number of synchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.CollectionConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.MapConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.QueueConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.config.RingbufferConfig
Sets the number of asynchronous backups.
setAsyncBackupCount(int) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setAsyncBackupCount(int) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setAsyncBackupCount(int) - Method in class com.hazelcast.internal.config.CardinalityEstimatorConfigReadOnly
 
setAsyncBackupCount(int) - Method in class com.hazelcast.internal.config.ListConfigReadOnly
 
setAsyncBackupCount(int) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setAsyncBackupCount(int) - Method in class com.hazelcast.internal.config.MultiMapConfigReadOnly
 
setAsyncBackupCount(int) - Method in class com.hazelcast.internal.config.QueueConfigReadOnly
 
setAsyncBackupCount(int) - Method in class com.hazelcast.internal.config.RingbufferConfigReadOnly
 
setAsyncBackupCount(int) - Method in class com.hazelcast.internal.config.SetConfigReadOnly
 
setAsyncFillup(boolean) - Method in class com.hazelcast.config.ReplicatedMapConfig
True if the replicated map is available for reads before the initial replication is completed, false otherwise.
setAsyncFillup(boolean) - Method in class com.hazelcast.internal.config.ReplicatedMapConfigReadOnly
 
setAsyncInternal(long, TimeUnit, Long, TimeUnit, Object, Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
setAsyncInternal(long, TimeUnit, Long, TimeUnit, Object, Object) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
setAsyncInternal(Object, Data, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
setAsyncStart(boolean) - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
Set true for non blocking HazelcastClient.newHazelcastClient().
setAttribute(String, String) - Method in class com.hazelcast.client.impl.MemberImpl
 
setAttribute(String, String) - Method in class com.hazelcast.cluster.impl.MemberImpl
 
setAttribute(String, String) - Method in interface com.hazelcast.cluster.Member
Defines a key-value pair string attribute for this member available to other cluster members.
setAttribute(String, String) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setAttribute(String, String) - Method in class com.hazelcast.internal.config.MemberAttributeConfigReadOnly
 
setAttribute(String, String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
setAttribute(Attribute) - Method in class com.hazelcast.internal.jmx.HazelcastMBean
 
setAttribute(Attribute) - Method in class com.hazelcast.internal.metrics.jmx.MetricsMBean
 
setAttribute(String) - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
setAttribute(String) - Method in interface com.hazelcast.query.PredicateBuilder
 
setAttributeConfigs(List<AttributeConfig>) - Method in class com.hazelcast.config.MapConfig
 
setAttributeConfigs(List<AttributeConfig>) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setAttributeConfigs(List<AttributeConfig>) - Method in class com.hazelcast.query.impl.getters.Extractors.Builder
 
setAttributeNode(Attr) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
setAttributeNodeNS(Attr) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
setAttributeNS(String, String, String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
setAttributes(List<String>) - Method in class com.hazelcast.config.IndexConfig
Sets index attributes.
setAttributes(Map<String, String>) - Method in class com.hazelcast.config.MemberAttributeConfig
 
setAttributes(List<String>) - Method in class com.hazelcast.internal.config.IndexConfigReadOnly
 
setAttributes(Map<String, String>) - Method in class com.hazelcast.internal.config.MemberAttributeConfigReadOnly
 
setAttributes(AttributeList) - Method in class com.hazelcast.internal.jmx.HazelcastMBean
 
setAttributes(AttributeList) - Method in class com.hazelcast.internal.metrics.jmx.MetricsMBean
 
setAutoRemoveStaleData(boolean) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets whether or not automatically removal of stale Hot Restart data is enabled.
setAveAge(long) - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
setAverageHitLatency(long) - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
Sets the average hit latency of this stats to the given average hit latency.
setAverageHitLatency(long) - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Sets the average hit latency to the given value.
setAverageHitSelectivity(double) - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
Sets the average hit selectivity of this stats to the given average hit selectivity.
setAverageHitSelectivity(double) - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Sets the average hit selectivity to the given value.
setAwsConfig(AwsConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets configuration to connect nodes in AWS environment.
setAwsConfig(AwsConfig) - Method in class com.hazelcast.config.JoinConfig
 
setAwsConfig(AwsConfig) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the AwsConfig used by the discovery mechanism for this WAN publisher.
setAzureConfig(AzureConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets configuration to connect nodes in Azure environment.
setAzureConfig(AzureConfig) - Method in class com.hazelcast.config.JoinConfig
 
setAzureConfig(AzureConfig) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the AzureConfig used by the discovery mechanism for this WAN publisher.
setBackup(long, long, Data) - Method in class com.hazelcast.collection.impl.list.ListContainer
 
setBackupAckToClientEnabled(boolean) - Method in class com.hazelcast.client.config.ClientConfig
This feature reduces number of hops and increase performance for smart clients.
setBackupCount(int) - Method in class com.hazelcast.config.CacheConfig
Sets the number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the number of synchronous backups for this ICache.
setBackupCount(int) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Sets the number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.config.CollectionConfig
Sets the number of synchronous backups for this collection.
setBackupCount(int) - Method in class com.hazelcast.config.MapConfig
Number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
Sets the number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.config.QueueConfig
Sets the number of synchronous backups for this queue.
setBackupCount(int) - Method in class com.hazelcast.config.RingbufferConfig
Sets the number of synchronous backups.
setBackupCount(int) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setBackupCount(int) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setBackupCount(int) - Method in class com.hazelcast.internal.config.CardinalityEstimatorConfigReadOnly
 
setBackupCount(int) - Method in class com.hazelcast.internal.config.ListConfigReadOnly
 
setBackupCount(int) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setBackupCount(int) - Method in class com.hazelcast.internal.config.MultiMapConfigReadOnly
 
setBackupCount(int) - Method in class com.hazelcast.internal.config.QueueConfigReadOnly
 
setBackupCount(int) - Method in class com.hazelcast.internal.config.RingbufferConfigReadOnly
 
setBackupCount(int) - Method in class com.hazelcast.internal.config.SetConfigReadOnly
 
setBackupCount(int) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
 
setBackupCount(int) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
setBackupCount(int) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
setBackupDir(File) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets base directory for all Hot Restart stores.
setBackupEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
setBackupEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
setBackupEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
setBackupEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
setBackupItemCount(int) - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
SetBackupOperation - Class in com.hazelcast.internal.longregister.operations
 
SetBackupOperation() - Constructor for class com.hazelcast.internal.longregister.operations.SetBackupOperation
 
SetBackupOperation(String, long) - Constructor for class com.hazelcast.internal.longregister.operations.SetBackupOperation
 
setBaseDir(File) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the base directory for persisting CP data.
setBaseDir(File) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets base directory for all Hot Restart stores.
setBatchMaxDelayMillis(int) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the maximum amount of time in milliseconds to wait before sending a batch of events to target cluster, if WanBatchReplicationPublisherConfig.getBatchSize() of events have not arrived within this duration.
setBatchPublisherConfigs(List<WanBatchReplicationPublisherConfig>) - Method in class com.hazelcast.config.WanReplicationConfig
Sets the list of WAN publisher configurations using the built-in batching WAN implementation for this WAN replication.
setBatchSize(int) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
setBatchSize(int) - Method in class com.hazelcast.config.MergePolicyConfig
Sets the batch size, which will be used to determine the number of entries to be sent in a merge operation.
setBatchSize(int) - Method in class com.hazelcast.config.QueryCacheConfig
Sets the batch size which will be used to determine number of events to be sent in a batch to QueryCache
setBatchSize(int) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the maximum batch size that can be sent to target cluster.
setBatchSize(int) - Method in class com.hazelcast.internal.config.MergePolicyConfigReadOnly
 
setBatchSize(int) - Method in class com.hazelcast.internal.config.QueryCacheConfigReadOnly
 
setBeans(MXBeansDTO) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
setBinary(boolean) - Method in class com.hazelcast.config.MultiMapConfig
Enables or disables binary (serialized) form for this MultiMap.
setBinary(boolean) - Method in class com.hazelcast.internal.config.MultiMapConfigReadOnly
 
setBinding() - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
setBindings(Bindings) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
Follows the same behavior of @link javax.script.ScriptEngineManager#setBindings(Bindings) This means that the same bindings are applied to all the underlying managers.
setBit(byte, int) - Static method in class com.hazelcast.internal.nio.Bits
Sets n-th bit of the byte value
setBit(int, int) - Static method in class com.hazelcast.internal.nio.Bits
Sets n-th bit of the integer value
setBlacklist(ClassFilter) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
setBlacklistedPrefixes(String) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Comma-separated list of class prefixes which will never be loaded remotely.
setBufferSize(int) - Method in class com.hazelcast.client.config.SocketOptions
Sets the SO_SNDBUF and SO_RCVBUF options to the specified value in KB
setBufferSize(int) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
setBufferSize(int) - Method in class com.hazelcast.config.QueryCacheConfig
Sets the maximum number of events which can be stored in a buffer of partition.
setBufferSize(int) - Method in class com.hazelcast.internal.config.QueryCacheConfigReadOnly
 
setByteOrder(ByteOrder) - Method in class com.hazelcast.config.SerializationConfig
Note that configuring use native byte order as enabled will override the byte order set by this method.
setByteOrder(ByteOrder) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
setByteOrder(ByteOrder) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
setBytes(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
setCacheConfigs(Map<String, CacheSimpleConfig>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setCacheConfigs(Map<String, CacheSimpleConfig>) - Method in class com.hazelcast.config.Config
Sets the map of cache configurations, mapped by config name.
setCacheConfigs(Map<String, CacheSimpleConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setCacheDeserializedValues(CacheDeserializedValues) - Method in class com.hazelcast.config.MapConfig
Configure de-serialized value caching.
setCacheDeserializedValues(CacheDeserializedValues) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setCacheEntryEventFilterFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
setCacheEntryEventFilterFactory(String) - Method in class com.hazelcast.internal.config.CacheSimpleEntryListenerConfigReadOnly
 
setCacheEntryListenerFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
setCacheEntryListenerFactory(String) - Method in class com.hazelcast.internal.config.CacheSimpleEntryListenerConfigReadOnly
 
setCacheEntryListeners(List<CacheSimpleEntryListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets a list of CacheSimpleEntryListenerConfig for this ICache.
setCacheEntryListeners(List<CacheSimpleEntryListenerConfig>) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setCacheLoader(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Set classname of a class to be used as CacheLoader.
setCacheLoaderFactory(Factory<? extends CacheLoader<K, V>>) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setCacheLoaderFactory(Factory<? extends CacheLoader<K, V>>) - Method in interface com.hazelcast.config.CacheConfiguration
Set the CacheLoader factory.
setCacheLoaderFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the factory for this CacheLoader.
setCacheLoaderFactory(Factory<? extends CacheLoader<K, V>>) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setCacheLoaderFactory(String) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setCacheLocalEntries(boolean) - Method in class com.hazelcast.config.NearCacheConfig
Sets if local entries are also cached in the Near Cache.
setCacheLocalEntries(boolean) - Method in class com.hazelcast.internal.config.NearCacheConfigReadOnly
 
setCacheManager(HazelcastCacheManager) - Method in interface com.hazelcast.cache.impl.ICacheInternal
Sets relevant HazelcastCacheManager to client/server.
setCacheName(String) - Method in class com.hazelcast.cache.impl.CacheEventContext
 
setCacheOptions(String) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
Set the cache ead-timeout params
setCacheWriter(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Set classname of a class to be used as CacheWriter.
setCacheWriterFactory(Factory<? extends CacheWriter<? super K, ? super V>>) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setCacheWriterFactory(Factory<? extends CacheWriter<? super K, ? super V>>) - Method in interface com.hazelcast.config.CacheConfiguration
Set the CacheWriter factory.
setCacheWriterFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the factory for this CacheWriter.
setCacheWriterFactory(Factory<? extends CacheWriter<? super K, ? super V>>) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setCacheWriterFactory(String) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setCaller(Address, long) - Method in interface com.hazelcast.cp.internal.CallerAware
Sets the caller information on the Raft op
setCaller(Address, long) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.AwaitOp
 
setCaller(Address, long) - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.LockOp
 
setCaller(Address, long) - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.TryLockOp
 
setCaller(Address, long) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.AcquirePermitsOp
 
setCallerAddress(Operation, Address) - Static method in class com.hazelcast.spi.impl.operationservice.OperationAccessor
 
setCallerUuid(UUID) - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
setCallId(Operation, long) - Static method in class com.hazelcast.spi.impl.operationservice.OperationAccessor
Assigns the supplied call ID to the supplied operation, thereby activating it.
setCallTimeout(long) - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
 
setCallTimeout(Operation, long) - Static method in class com.hazelcast.spi.impl.operationservice.OperationAccessor
Sets the call timeout in milliseconds for the Operation.
setCandidateClusterContext(CandidateClusterContext) - Method in interface com.hazelcast.client.impl.connection.ClientConnectionManager
 
setCandidateClusterContext(CandidateClusterContext) - Method in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
setCapacity(int) - Method in class com.hazelcast.config.DurableExecutorConfig
Sets the ring buffer capacity of the executor task.
setCapacity(int) - Method in class com.hazelcast.config.EventJournalConfig
Sets the capacity of the event journal.
setCapacity(int) - Method in class com.hazelcast.config.RingbufferConfig
Sets the capacity of the ringbuffer.
setCapacity(int) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the capacity of the executor The capacity represents the maximum number of tasks that a scheduler can have at any given point in time per partition.
setCapacity(int) - Method in class com.hazelcast.internal.config.DurableExecutorConfigReadOnly
 
setCapacity(int) - Method in class com.hazelcast.internal.config.EventJournalConfigReadOnly
 
setCapacity(int) - Method in class com.hazelcast.internal.config.RingbufferConfigReadOnly
 
setCapacity(int) - Method in class com.hazelcast.internal.config.ScheduledExecutorConfigReadOnly
 
setCardinalityEstimatorConfigs(Map<String, CardinalityEstimatorConfig>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setCardinalityEstimatorConfigs(Map<String, CardinalityEstimatorConfig>) - Method in class com.hazelcast.config.Config
Sets the map of cardinality estimator configurations, mapped by config name.
setCardinalityEstimatorConfigs(Map<String, CardinalityEstimatorConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setChannel(Channel) - Method in class com.hazelcast.internal.networking.ChannelHandler
Sets the Channel.
setChannelOptions(Channel, EndpointConfig) - Static method in class com.hazelcast.internal.nio.IOUtil
Sets configured channel options on given Channel.
setCheckClassDefErrors(boolean) - Method in class com.hazelcast.config.SerializationConfig
When enabled, serialization system will check for class definitions error at start and throw an Serialization Exception with error definition.
setCheckClassDefErrors(boolean) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
setCheckClassDefErrors(boolean) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
setClass(Class<? extends Serializer>) - Method in class com.hazelcast.config.SerializerConfig
Sets the class of the serializer implementation.
setClassCacheMode(UserCodeDeploymentConfig.ClassCacheMode) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Configure caching of classes loaded from remote members.
setClassDefinitions(Set<ClassDefinition>) - Method in class com.hazelcast.config.SerializationConfig
 
setClasses(Collection<String>) - Method in class com.hazelcast.config.ClassFilter
 
setClassLoader(ClassLoader) - Method in class com.hazelcast.client.config.ClientConfig
Sets the classLoader which is used by serialization and listener configuration
setClassLoader(ClassLoader) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setClassLoader(ClassLoader) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setClassLoader(ClassLoader) - Method in class com.hazelcast.config.Config
Sets the class-loader to be used during de-serialization and as context class-loader of Hazelcast internal threads.
setClassLoader(ClassLoader) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setClassLoader(ClassLoader) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
setClassLoader(ClassLoader) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
setClassLoader(ClassLoader) - Method in class com.hazelcast.query.impl.getters.Extractors.Builder
 
setClassName(String) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
Sets class name of proxy factory
setClassName(String) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
setClassName(String) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
Sets the name of the class implementing WanReplicationPublisher.
setClassName(String) - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
setClassName(String) - Method in class com.hazelcast.config.CustomWanPublisherConfig
 
setClassName(String) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
setClassName(String) - Method in class com.hazelcast.config.GlobalSerializerConfig
 
setClassName(String) - Method in class com.hazelcast.config.ListenerConfig
Sets the class name of the EventListener.
setClassName(String) - Method in class com.hazelcast.config.LoginModuleConfig
 
setClassName(String) - Method in class com.hazelcast.config.MapStoreConfig
Sets the name for the MapStore implementation class
setClassName(String) - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
setClassName(String) - Method in class com.hazelcast.config.PermissionPolicyConfig
 
setClassName(String) - Method in class com.hazelcast.config.PredicateConfig
Sets the class name of the Predicate.
setClassName(String) - Method in class com.hazelcast.config.QueueStoreConfig
 
setClassName(String) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setClassName(String) - Method in class com.hazelcast.config.SecurityInterceptorConfig
 
setClassName(String) - Method in class com.hazelcast.config.SerializerConfig
Sets the class name of the serializer implementation.
setClassName(String) - Method in class com.hazelcast.config.ServiceConfig
 
setClassName(String) - Method in class com.hazelcast.config.SocketInterceptorConfig
Sets the name for the SocketInterceptor implementation class.
setClassName(String) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
setClassName(String) - Method in class com.hazelcast.config.WanConsumerConfig
Sets the fully qualified class name of the class implementing WanReplicationConsumer.
setClassName(String) - Method in class com.hazelcast.internal.config.CachePartitionLostListenerConfigReadOnly
 
setClassName(String) - Method in class com.hazelcast.internal.config.EntryListenerConfigReadOnly
 
setClassName(String) - Method in class com.hazelcast.internal.config.ItemListenerConfigReadOnly
 
setClassName(String) - Method in class com.hazelcast.internal.config.ListenerConfigReadOnly
 
setClassName(String) - Method in class com.hazelcast.internal.config.MapPartitionLostListenerConfigReadOnly
 
setClassName(String) - Method in class com.hazelcast.internal.config.MapStoreConfigReadOnly
 
setClassName(String) - Method in class com.hazelcast.internal.config.PredicateConfigReadOnly
 
setClassName(String) - Method in class com.hazelcast.internal.config.QueueStoreConfigReadOnly
 
setClassName(String) - Method in class com.hazelcast.internal.config.RingbufferStoreConfigReadOnly
 
setClassNames(List<String>) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
setClassVersion(int, int, int) - Method in interface com.hazelcast.internal.serialization.PortableContext
 
SetClearCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes all of the elements from this set (optional operation).
SetClearCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetClearCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetClearMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
SetClearMessageTask
SetClearMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetClearMessageTask
 
setClientBlockUnmappedActions(boolean) - Method in class com.hazelcast.config.SecurityConfig
Block or allow actions, submitted as tasks in an Executor from clients and have no permission mappings.
setClientBlockUnmappedActions(boolean) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
setClientCallId(long) - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
setClientConfigs(List<ClientConfig>) - Method in class com.hazelcast.client.config.ClientFailoverConfig
 
setClientEndpointConfig(ServerSocketEndpointConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
Sets the server socket endpoint config for CLIENT protocol.
setClientHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.instance.impl.OutOfMemoryErrorDispatcher
 
setClientIcmpPingConfig(ClientIcmpPingConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
ICMP ping is used to detect if machine that a remote hazelcast member runs on alive or not
setClientName(String) - Method in class com.hazelcast.client.config.ClientConfig
 
setClientPermissionConfigs(Set<PermissionConfig>) - Method in class com.hazelcast.config.SecurityConfig
 
setClientPermissionConfigs(Set<PermissionConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
Updates client permission configuration cluster-wide.
setClientPolicyConfig(PermissionPolicyConfig) - Method in class com.hazelcast.config.SecurityConfig
 
setClientPolicyConfig(PermissionPolicyConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
setClientRealm(String) - Method in class com.hazelcast.config.SecurityConfig
 
setClientRealm(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
setClientRealmConfig(String, RealmConfig) - Method in class com.hazelcast.config.SecurityConfig
 
setClientRealmConfig(String, RealmConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
setClients(Collection<ClientEndPointDTO>) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
setClientStatistics(String) - Method in interface com.hazelcast.client.impl.ClientEndpoint
Updates to the latest client statistics.
setClientStatistics(String) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
setClientStats(Map<UUID, String>) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
setClientVersion(String) - Method in interface com.hazelcast.client.impl.ClientEndpoint
 
setClientVersion(String) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
setCloudConfig(ClientCloudConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
setClusterDataRecoveryPolicy(HotRestartClusterDataRecoveryPolicy) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets the policy to be used when the cluster is started
setClusterHotRestartStatus(ClusterHotRestartStatusDTO) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
setClusterName(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setClusterName(String) - Method in class com.hazelcast.config.Config
Sets the cluster name uniquely identifying the hazelcast cluster.
setClusterName(String) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the cluster name used as an endpoint group password for authentication on the target endpoint.
setClusterName(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setClusterName(String) - Method in class com.hazelcast.internal.management.TimedMemberState
 
setClusterStartTime(long) - Method in class com.hazelcast.internal.cluster.impl.ClusterClockImpl
 
setClusterVersion(Version) - Method in class com.hazelcast.internal.cluster.impl.ClusterStateManager
 
setCmdGet(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
setCmdSet(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
setCmdTouch(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
setCoalesce(boolean) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
setCoalesce(boolean) - Method in class com.hazelcast.config.QueryCacheConfig
Set true to enable coalescing, otherwise set false.
setCoalesce(boolean) - Method in class com.hazelcast.internal.config.QueryCacheConfigReadOnly
 
setCollectionIntervalSeconds(int) - Method in class com.hazelcast.config.MetricsConfig
Sets the metrics collection interval in seconds.
SetCommand - Class in com.hazelcast.internal.ascii.memcache
 
SetCommand(TextCommandConstants.TextCommandType, String, int, int, int, boolean) - Constructor for class com.hazelcast.internal.ascii.memcache.SetCommand
 
SetCommandParser - Class in com.hazelcast.internal.ascii.memcache
 
SetCommandParser(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.internal.ascii.memcache.SetCommandParser
 
SetCommandProcessor - Class in com.hazelcast.internal.ascii.memcache
 
SetCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.memcache.SetCommandProcessor
 
setCommitIndexAdvanceCountToSnapshot(int) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setCommittedHeap(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
setCommittedNativeMemory(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
setComparator(EvictionPolicyComparator) - Method in class com.hazelcast.config.EvictionConfig
Sets the instance of the configured EvictionPolicyComparator implementation.
setComparator(EvictionPolicyComparator) - Method in class com.hazelcast.internal.config.EvictionConfigReadOnly
 
setComparatorClassName(String) - Method in class com.hazelcast.config.EvictionConfig
Sets the class name of the configured EvictionPolicyComparator implementation.
setComparatorClassName(String) - Method in class com.hazelcast.internal.config.EvictionConfigReadOnly
 
SetCompareAndRemoveAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes from this set all of its elements that are contained in the specified collection (optional operation).
SetCompareAndRemoveAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetCompareAndRemoveAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetCompareAndRemoveAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
SetCompareAndRemoveAllMessageTask
SetCompareAndRemoveAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRemoveAllMessageTask
 
SetCompareAndRetainAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Retains only the elements in this set that are contained in the specified collection (optional operation).
SetCompareAndRetainAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetCompareAndRetainAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetCompareAndRetainAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
SetCompareAndRetainAllMessageTask
SetCompareAndRetainAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRetainAllMessageTask
 
setCompletionId(int) - Method in class com.hazelcast.cache.impl.CacheEventContext
 
setCompletionId(int) - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
 
setCompletionId(int) - Method in interface com.hazelcast.cache.impl.operation.MutableOperation
 
setCompletionId(int) - Method in class com.hazelcast.cache.impl.operation.MutatingCacheOperation
 
setConfig(QueueConfig, NodeEngine, QueueService) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
 
SetConfig - Class in com.hazelcast.config
Contains the configuration for an ISet.
SetConfig() - Constructor for class com.hazelcast.config.SetConfig
 
SetConfig(String) - Constructor for class com.hazelcast.config.SetConfig
 
SetConfig(SetConfig) - Constructor for class com.hazelcast.config.SetConfig
 
setConfig(SerializationConfig) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
setConfig(SerializationConfig) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
setConfigClassLoader(ClassLoader) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setConfigObject(Object) - Method in class com.hazelcast.config.ServiceConfig
 
setConfigPatternMatcher(ConfigPatternMatcher) - Method in class com.hazelcast.client.config.ClientConfig
Sets the pattern matcher which is used to match item names to configuration objects.
setConfigPatternMatcher(ConfigPatternMatcher) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setConfigPatternMatcher(ConfigPatternMatcher) - Method in class com.hazelcast.config.Config
Sets the pattern matcher which is used to match item names to configuration objects.
setConfigPatternMatcher(ConfigPatternMatcher) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
SetConfigReadOnly - Class in com.hazelcast.internal.config
Contains configuration for Set(read only)
SetConfigReadOnly(SetConfig) - Constructor for class com.hazelcast.internal.config.SetConfigReadOnly
 
setConfigurationFile(File) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setConfigurationFile(File) - Method in class com.hazelcast.config.Config
Sets the File from which this configuration has been retrieved and created.
setConfigurationFile(File) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setConfigurationService(ConfigurationService) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setConfigurationUrl(URL) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setConfigurationUrl(URL) - Method in class com.hazelcast.config.Config
Sets the URL from which this configuration has been retrieved and created.
setConfigurationUrl(URL) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setConn(Connection) - Method in class com.hazelcast.internal.nio.Packet
Sets the Connection this Packet is send with.
setConnected(boolean) - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
setConnectedServerVersion(String) - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
setConnection(Connection) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
setConnection(Operation, Connection) - Static method in class com.hazelcast.spi.impl.operationservice.OperationAccessor
 
setConnectionManagerBean(ConnectionManagerDTO) - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
 
setConnectionRetryConfig(ConnectionRetryConfig) - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
Connection Retry Config is controls the period among the retries and when should a client gave up retrying.
setConnectionStrategyConfig(ClientConnectionStrategyConfig) - Method in class com.hazelcast.client.config.ClientConfig
 
setConnectionTimeout(int) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
setConnectionTimeoutSeconds(int) - Method in class com.hazelcast.config.AwsConfig
setConnectionTimeoutSeconds(int) - Method in class com.hazelcast.config.TcpIpConfig
Sets the connection timeout.
setConsistencyCheckStrategy(ConsistencyCheckStrategy) - Method in class com.hazelcast.config.WanSyncConfig
Sets the strategy for checking consistency of data between source and target cluster.
setConsumerThread(Thread) - Method in class com.hazelcast.internal.util.concurrent.MPSCQueue
Sets the consumer thread.
SetContainer - Class in com.hazelcast.collection.impl.set
 
SetContainer() - Constructor for class com.hazelcast.collection.impl.set.SetContainer
 
SetContainer(String, NodeEngine) - Constructor for class com.hazelcast.collection.impl.set.SetContainer
 
SetContainsAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns true if this set contains all of the elements of the specified collection.
SetContainsAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetContainsAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetContainsAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
SetContainsAllMessageTask
SetContainsAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetContainsAllMessageTask
 
SetContainsCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns true if this set contains the specified element.
SetContainsCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetContainsCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetContainsMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
SetContainsMessageTask
SetContainsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetContainsMessageTask
 
setContentType(byte[]) - Method in class com.hazelcast.internal.ascii.rest.RestValue
 
setContextClassLoader(ClassLoader) - Method in class com.hazelcast.internal.util.executor.HazelcastManagedThread
 
setCorrelationId(long) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
setCost(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
setCost(long) - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
setCPMemberCount(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the CP member count to initialize CP Subsystem.
setCpMemberUuid(UUID) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
setCPSubsystemConfig(CPSubsystemConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setCPSubsystemConfig(CPSubsystemConfig) - Method in class com.hazelcast.config.Config
Set CP subsystem configuration
setCPSubsystemConfig(CPSubsystemConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setCRDTReplicationConfig(CRDTReplicationConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setCRDTReplicationConfig(CRDTReplicationConfig) - Method in class com.hazelcast.config.Config
Sets the replication configuration for CRDT implementations.
setCRDTReplicationConfig(CRDTReplicationConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setCreationTime(long) - Method in class com.hazelcast.cache.impl.CacheEventContext
 
setCreationTime(long) - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
setCreationTime(long) - Method in interface com.hazelcast.cache.impl.record.CacheRecord
Sets the creation time of this Evictable in milliseconds.
setCreationTime(long) - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
setCreationTime(long) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecord
Sets the creation time of this Evictable in milliseconds.
setCreationTime(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
setCreationTime(long) - Method in interface com.hazelcast.map.impl.record.Record
 
setCreationTime(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
 
setCreationTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
setCreationTime(long) - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
Sets the creation of this stats to the given creation time.
setCreationTime(long) - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Sets the creation time the given value.
setCreationTime(long) - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
setCreationTime(long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
setCreationTime(long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
setCreationTime(long) - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
setCreationTime(long) - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
setCreationTime(long) - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
setCreationTime(long) - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
setCredentials(Credentials) - Method in class com.hazelcast.client.config.ClientConfig
Shortcut for getSecurityConfig().setCredentials()
setCredentials(Credentials) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
setCredentials(Credentials) - Method in class com.hazelcast.config.security.RealmConfig
 
setCredentialsFactoryConfig(CredentialsFactoryConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
setCredentialsFactoryConfig(CredentialsFactoryConfig) - Method in class com.hazelcast.config.security.RealmConfig
 
setCredentialsIdentityConfig(CredentialsIdentityConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
setCredentialsIdentityConfig(CredentialsIdentityConfig) - Method in class com.hazelcast.config.security.RealmConfig
 
setCurrConnections(int) - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
setCurrentKeyAlias(String) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Sets the alias for the current encryption key entry.
setCurrentSequence(String, int, long) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataGenerator
 
setCurrentThread(Thread) - Method in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
Sets the thread that is running this OperationRunner instance.
setCustomPublisherConfigs(List<CustomWanPublisherConfig>) - Method in class com.hazelcast.config.WanReplicationConfig
Sets the list of custom WAN publisher implementations for this WAN replication.
setData(Data) - Method in class com.hazelcast.collection.impl.queue.QueueItem
 
setDataKey(Data) - Method in class com.hazelcast.cache.impl.CacheEventContext
 
setDataKey(Data) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
setDataLoadTimeoutSeconds(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the timeout duration for CP members to restore their data from stable storage.
setDataLoadTimeoutSeconds(int) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets data load timeout for hot-restart process, all members in the cluster should complete restoring their local data before this timeout.
setDataNewValue(Data) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
setDataOldValue(Data) - Method in class com.hazelcast.cache.impl.CacheEventContext
 
setDataOldValue(Data) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
setDataSerializableFactories(Map<Integer, DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
 
setDataSerializableFactoryClasses(Map<Integer, String>) - Method in class com.hazelcast.config.SerializationConfig
 
setDataValue(Data) - Method in class com.hazelcast.cache.impl.CacheEventContext
 
setDecrHits(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
setDecrMisses(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
setDefaultReadTimeout(long) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
Set default cache value retrieval timeout.
setDefaultsDisabled(boolean) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
setDelaySeconds(int) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
setDelaySeconds(int) - Method in class com.hazelcast.config.QueryCacheConfig
Sets the minimum number of delay seconds which an event waits in the buffer of node before sending to a QueryCache
setDelaySeconds(int) - Method in class com.hazelcast.internal.config.QueryCacheConfigReadOnly
 
setDeleteHits(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
setDeleteMisses(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
setDeprecatedName(String) - Method in class com.hazelcast.spi.properties.HazelcastProperty
Sets the deprecated name of ths property.
setDepth(int) - Method in class com.hazelcast.config.MerkleTreeConfig
Sets the depth of the merkle tree.
setDepth(int) - Method in class com.hazelcast.internal.config.MerkleTreeConfigReadOnly
 
setDirectory(String) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
setDirectory(String) - Method in class com.hazelcast.internal.config.NearCachePreloaderConfigReadOnly
 
setDirtyEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
setDirtyEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
setDisablePerEntryInvalidationEvents(boolean) - Method in class com.hazelcast.config.CacheConfig
Sets invalidation events disabled status for per entry.
setDisablePerEntryInvalidationEvents(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets invalidation events disabled status for per entry.
setDisablePerEntryInvalidationEvents(boolean) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setDisablePerEntryInvalidationEvents(boolean) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Defines the Discovery Provider SPI configuration
setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.config.JoinConfig
Sets a custom defined DiscoveryConfig
setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the DiscoveryConfig used by the discovery mechanism for this WAN publisher.
setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setDiscoveryMode(DiscoveryMode) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setDiscoveryNode(DiscoveryNode) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setDiscoveryPeriodSeconds(int) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the period in seconds in which WAN tries to discover new target endpoints and reestablish connections to failed endpoints.
setDiscoveryServiceProvider(DiscoveryServiceProvider) - Method in class com.hazelcast.config.DiscoveryConfig
 
setDiscoveryServiceProvider(DiscoveryServiceProvider) - Method in class com.hazelcast.internal.config.DiscoveryConfigReadOnly
 
setDiscoveryStrategyConfigs(List<DiscoveryStrategyConfig>) - Method in class com.hazelcast.config.DiscoveryConfig
Sets the strategy configurations for this discovery config.
setDiscoveryStrategyConfigs(List<DiscoveryStrategyConfig>) - Method in class com.hazelcast.internal.config.DiscoveryConfigReadOnly
 
setDiscoveryStrategyFactory(DiscoveryStrategyFactory) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
setDiscoveryToken(String) - Method in class com.hazelcast.client.config.ClientCloudConfig
 
setDoneCallback(Runnable) - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Sets a callback that will respond to the "task done" event for the invocation this builder is about to create.
setDurability(int) - Method in class com.hazelcast.config.DurableExecutorConfig
Sets the durability of the executor
setDurability(int) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the durability of the executor The durability represents the number of replicas that exist in a cluster for any given partition-owned task.
setDurability(int) - Method in class com.hazelcast.internal.config.DurableExecutorConfigReadOnly
 
setDurability(int) - Method in class com.hazelcast.internal.config.ScheduledExecutorConfigReadOnly
 
setDurability(int) - Method in class com.hazelcast.transaction.TransactionOptions
Sets the transaction durability.
setDurableExecutorConfigs(Map<String, DurableExecutorConfig>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setDurableExecutorConfigs(Map<String, DurableExecutorConfig>) - Method in class com.hazelcast.config.Config
Sets the map of durable executor configurations, mapped by config name.
setDurableExecutorConfigs(Map<String, DurableExecutorConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setEchoFailFastOnStartup(boolean) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
setEmptyQueueTtl(int) - Method in class com.hazelcast.config.QueueConfig
Sets the TTL (time to live) for emptying the Queue.
setEmptyQueueTtl(int) - Method in class com.hazelcast.internal.config.QueueConfigReadOnly
 
setEnableCompression(boolean) - Method in class com.hazelcast.config.SerializationConfig
Enables compression when default java serialization is used.
setEnableCompression(boolean) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
setEnableCompression(boolean) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
setEnabled(boolean) - Method in class com.hazelcast.client.config.ClientCloudConfig
 
setEnabled(boolean) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
setEnabled(boolean) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
setEnabled(boolean) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
setEnabled(boolean) - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
Enables and disables this configuration.
setEnabled(boolean) - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Enables or disables the join mechanism based on the given discovery config.
setEnabled(boolean) - Method in class com.hazelcast.config.AwsConfig
Enables or disables the AWS join mechanism.
setEnabled(boolean) - Method in class com.hazelcast.config.EventJournalConfig
Enables or disables the event journal.
setEnabled(boolean) - Method in class com.hazelcast.config.HotRestartConfig
Sets whether hot restart is enabled on related data structure.
setEnabled(boolean) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets whether hot restart is enabled on this member.
setEnabled(boolean) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Set whether the ICMP failure detector should be enabled or not.
setEnabled(boolean) - Method in class com.hazelcast.config.InterfacesConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.ManagementCenterConfig
Set to true to enable management center, false to disable.
setEnabled(boolean) - Method in class com.hazelcast.config.MapStoreConfig
Enables and disables this configuration
setEnabled(boolean) - Method in class com.hazelcast.config.MCMutualAuthConfig
Enables and disables this configuration.
setEnabled(boolean) - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.MemcacheProtocolConfig
Enables or disables the MEMCACHE protocol on the member.
setEnabled(boolean) - Method in class com.hazelcast.config.MerkleTreeConfig
Enables or disables the merkle tree.
setEnabled(boolean) - Method in class com.hazelcast.config.MetricsConfig
Sets whether metrics collection should be enabled for the node.
setEnabled(boolean) - Method in class com.hazelcast.config.MulticastConfig
Enables or disables the multicast discovery mechanism
setEnabled(boolean) - Method in class com.hazelcast.config.NativeMemoryConfig
Enables or disables native memory allocation.
setEnabled(boolean) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.PartitionGroupConfig
Enables or disables this PartitionGroupConfig.
setEnabled(boolean) - Method in class com.hazelcast.config.QueueStoreConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.RestApiConfig
Enables or disables the REST API on the member.
setEnabled(boolean) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.SecurityConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.ServiceConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.SocketInterceptorConfig
Enables and disables this configuration.
setEnabled(boolean) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
setEnabled(boolean) - Method in class com.hazelcast.config.SSLConfig
Enables and disables this configuration.
setEnabled(boolean) - Method in class com.hazelcast.config.TcpIpConfig
Enables or disables the Tcp/Ip join mechanism.
setEnabled(boolean) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Enable or disable User Code Deployment.
setEnabled(boolean) - Method in class com.hazelcast.internal.config.EventJournalConfigReadOnly
 
setEnabled(boolean) - Method in class com.hazelcast.internal.config.HotRestartConfigReadOnly
 
setEnabled(boolean) - Method in class com.hazelcast.internal.config.MapStoreConfigReadOnly
 
setEnabled(boolean) - Method in class com.hazelcast.internal.config.MerkleTreeConfigReadOnly
 
setEnabled(boolean) - Method in class com.hazelcast.internal.config.NearCachePreloaderConfigReadOnly
 
setEnabled(boolean) - Method in class com.hazelcast.internal.config.QueueStoreConfigReadOnly
 
setEnabled(boolean) - Method in class com.hazelcast.internal.config.RingbufferStoreConfigReadOnly
 
setEnabled(boolean) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
setEnableDefaults(boolean) - Method in class com.hazelcast.config.ServicesConfig
 
setEnabledGroups(Collection<RestEndpointGroup>) - Method in class com.hazelcast.config.RestApiConfig
 
setEnabledGroups(Collection<RestEndpointGroup>) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setEnableSharedObject(boolean) - Method in class com.hazelcast.config.SerializationConfig
Enables shared object when default java serialization is used.
setEnableSharedObject(boolean) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
setEnableSharedObject(boolean) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
setEncryptionAtRestConfig(EncryptionAtRestConfig) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets the Hot Restart Encryption at Rest configuration.
setEndpoint(String) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the WAN endpoint configuration qualifier.
setEndPoint(Address) - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
setEndpointConfigs(Map<EndpointQualifier, EndpointConfig>) - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
setEndpointManager(EndpointManager) - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
 
setEndpoints(Set<String>) - Method in class com.hazelcast.config.PermissionConfig
 
setEndpoints(Map<EndpointQualifier, Address>) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
setEntryCostEstimator(EntryCostEstimator) - Method in interface com.hazelcast.map.impl.recordstore.Storage
 
setEntryCostEstimator(EntryCostEstimator) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
setEntryCounting(boolean) - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap
 
setEntryCounting(boolean) - Method in interface com.hazelcast.cache.impl.record.CacheRecordMap
Sets the entry counting behaviour.
setEntryListener(String, String, QueryCacheConfig) - Method in class com.hazelcast.map.impl.querycache.subscriber.AbstractQueryCacheConfigurator
 
setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.MapConfig
 
setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.MultiMapConfig
Sets the list of entry listeners (listens for when entries are added or removed) for this MultiMap.
setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.QueryCacheConfig
 
setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.internal.config.MultiMapConfigReadOnly
 
setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.internal.config.QueryCacheConfigReadOnly
 
setEntryView(WanMapEntryView<Data, Data>) - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
 
setErrorHandler(TcpIpConnectionErrorHandler) - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
setEurekaConfig(EurekaConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets configuration to connect nodes in Eureka environment.
setEurekaConfig(EurekaConfig) - Method in class com.hazelcast.config.JoinConfig
 
setEurekaConfig(EurekaConfig) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the EurekaConfig used by the discovery mechanism for this WAN publisher.
setEventHandler(EventHandler) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocation
 
setEventJournalConfig(EventJournalConfig) - Method in class com.hazelcast.config.AbstractCacheConfig
Sets the EventJournalConfig for this CacheConfiguration
setEventJournalConfig(EventJournalConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the EventJournalConfig for this CacheSimpleConfig
setEventJournalConfig(EventJournalConfig) - Method in class com.hazelcast.config.MapConfig
Sets the EventJournalConfig for this MapConfig
setEventJournalConfig(EventJournalConfig) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setEventJournalConfig(EventJournalConfig) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setEventListener(ManagementCenterEventListener) - Method in class com.hazelcast.internal.management.ManagementCenterService
 
setEventServiceBean(EventServiceDTO) - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
 
setEventType(CacheEventType) - Method in class com.hazelcast.cache.impl.CacheEventContext
 
setEventType(int) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.CacheConfig
Sets the EvictionConfig instance for eviction configuration for this ICache.
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the eviction configuration for this ICache.
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.NearCacheConfig
Sets the eviction configuration for this Near Cache.
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.QueryCacheConfig
Sets the EvictionConfig instance for this QueryCache
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.internal.config.NearCacheConfigReadOnly
 
setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.internal.config.QueryCacheConfigReadOnly
 
setEvictionConfigHolder(EvictionConfigHolder) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
setEvictionCriteriaNumber(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
Needed for client protocol compatibility.
setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.EvictionConfig
Sets the EvictionPolicy of this eviction configuration.
setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.MapConfig
Sets the EvictionPolicy.
setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.internal.config.EvictionConfigReadOnly
 
setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setEvictor(Evictor) - Method in class com.hazelcast.map.impl.MapContainer
 
setExecutionCallback(ExecutionCallback<Object>) - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Sets the ExecutionCallback.
setExecutor(Executor) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Sets the Executor that is going to process the event.
setExecutor(Executor) - Method in class com.hazelcast.config.ReliableTopicConfig
Sets the executor that is going to process the event.
setExecutor(Executor) - Method in class com.hazelcast.internal.config.ReliableTopicConfigReadOnly
 
setExecutorConfigs(Map<String, ExecutorConfig>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setExecutorConfigs(Map<String, ExecutorConfig>) - Method in class com.hazelcast.config.Config
Sets the map of executor configurations, mapped by config name.
setExecutorConfigs(Map<String, ExecutorConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setExecutorPoolSize(int) - Method in class com.hazelcast.client.config.ClientConfig
Sets Client side Executor pool size.
setExpirationTime(long) - Method in class com.hazelcast.cache.impl.CacheEventContext
 
setExpirationTime(long) - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
setExpirationTime(long) - Method in interface com.hazelcast.internal.eviction.Expirable
Sets the expiration time in milliseconds.
setExpirationTime(long) - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
setExpirationTime(Record) - Static method in class com.hazelcast.map.impl.ExpirationTimeSetter
Sets expiration time if statistics are enabled.
setExpirationTime(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
setExpirationTime(long) - Method in interface com.hazelcast.map.impl.record.Record
 
setExpirationTime(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
 
setExpirationTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
setExpirationTime(long) - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
setExpirationTime(long) - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
setExpirationTimes(long, long, Record, MapConfig, boolean) - Static method in class com.hazelcast.map.impl.ExpirationTimeSetter
Updates records TTL and expiration time.
setExpiryPolicy(K, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Associates the specified key with the given ExpiryPolicy.
setExpiryPolicy(Set<? extends K>, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
Associates the specified key with the given ExpiryPolicy.
setExpiryPolicy(Collection<Data>, Object, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
setExpiryPolicy(Data) - Method in class com.hazelcast.cache.impl.CacheEventContext
 
setExpiryPolicy(K, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.CacheProxy
 
setExpiryPolicy(Set<? extends K>, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.CacheProxy
 
setExpiryPolicy(Collection<Data>, Object, UUID) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Sets expiry policy for the records with given keys if and only if there is a value currently mapped by the key
setExpiryPolicy(Data) - Method in class com.hazelcast.cache.impl.record.CacheDataRecord
 
setExpiryPolicy(ExpiryPolicy) - Method in class com.hazelcast.cache.impl.record.CacheObjectRecord
 
setExpiryPolicy(E) - Method in interface com.hazelcast.cache.impl.record.CacheRecord
Sets the expiry policy for this record.
setExpiryPolicy(Set<? extends K>, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
setExpiryPolicy(K, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
setExpiryPolicy(Set<K>, ExpiryPolicy) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
setExpiryPolicy(K, ExpiryPolicy) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
setExpiryPolicy(Set<K>, ExpiryPolicy) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
setExpiryPolicy(K, ExpiryPolicy) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
setExpiryPolicy(Set<K>, ExpiryPolicy) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
setExpiryPolicy(K, ExpiryPolicy) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
setExpiryPolicy(Set<K>, ExpiryPolicy) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
setExpiryPolicy(K, ExpiryPolicy) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
setExpiryPolicy(Set<K>, ExpiryPolicy) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
setExpiryPolicy(K, ExpiryPolicy) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in interface com.hazelcast.config.CacheConfiguration
Set the Factory for the ExpiryPolicy.
setExpiryPolicyFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the factory for this ExpiryPolicy.
setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setExpiryPolicyFactory(String) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the factory configuration for this ExpiryPolicy.
setExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setExpiryPolicyInternal(Set<? extends K>, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
setExpiryPolicyInternal(K, ExpiryPolicy) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
setExtractorClassName(String) - Method in class com.hazelcast.config.AttributeConfig
Sets the full class name of the extractor in a String format, e.g.
setExtractorClassName(String) - Method in class com.hazelcast.internal.config.AttributeConfigReadOnly
 
setFactoryClassName(String) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
setFactoryClassName(String) - Method in class com.hazelcast.config.MapStoreConfig
Sets the name for the MapStoreFactory implementation class
setFactoryClassName(String) - Method in class com.hazelcast.config.MCMutualAuthConfig
Sets the name for the implementation class.
setFactoryClassName(String) - Method in class com.hazelcast.config.QueueStoreConfig
 
setFactoryClassName(String) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setFactoryClassName(String) - Method in class com.hazelcast.config.SSLConfig
Sets the name for the implementation class.
setFactoryClassName(String) - Method in class com.hazelcast.internal.config.MapStoreConfigReadOnly
 
setFactoryClassName(String) - Method in class com.hazelcast.internal.config.QueueStoreConfigReadOnly
 
setFactoryClassName(String) - Method in class com.hazelcast.internal.config.RingbufferStoreConfigReadOnly
 
setFactoryImpl(ClientProxyFactory) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
Sets factory implementation of proxy factory
setFactoryImplementation(Data) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
setFactoryImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfig
Sets the map store factory implementation object.
setFactoryImplementation(Object) - Method in class com.hazelcast.config.MCMutualAuthConfig
Sets the implementation object.
setFactoryImplementation(QueueStoreFactory) - Method in class com.hazelcast.config.QueueStoreConfig
 
setFactoryImplementation(RingbufferStoreFactory) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setFactoryImplementation(Object) - Method in class com.hazelcast.config.SSLConfig
Sets the implementation object.
setFactoryImplementation(Object) - Method in class com.hazelcast.internal.config.MapStoreConfigReadOnly
 
setFactoryImplementation(QueueStoreFactory) - Method in class com.hazelcast.internal.config.QueueStoreConfigReadOnly
 
setFactoryImplementation(RingbufferStoreFactory) - Method in class com.hazelcast.internal.config.RingbufferStoreConfigReadOnly
 
setFailFastOnStartup(boolean) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Sets whether the member should fail-fast on startup if ICMP is not allowed by the underlying OS.
setFailOnIndeterminateOperationState(boolean) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the value to determine if CP Subsystem calls will fail when result of an API call becomes indeterminate.
setFailOnIndeterminateOperationState(boolean) - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Enables / disables throwing IndeterminateOperationStateException for this invocation.
setFailOnMaxBackoff(boolean) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
 
setFilters(List<String>) - Method in class com.hazelcast.config.WanReplicationRef
Sets the list of class names implementing the CacheWanEventFilter or MapWanEventFilter for filtering outbound WAN replication events.
setFilters(List<String>) - Method in class com.hazelcast.internal.config.WanReplicationRefReadOnly
 
setFlakeIdGeneratorConfigMap(Map<String, ClientFlakeIdGeneratorConfig>) - Method in class com.hazelcast.client.config.ClientConfig
Sets the map of FlakeIdGenerator configurations, mapped by config name.
setFlakeIdGeneratorConfigs(Map<String, FlakeIdGeneratorConfig>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setFlakeIdGeneratorConfigs(Map<String, FlakeIdGeneratorConfig>) - Method in class com.hazelcast.config.Config
Sets the map of FlakeIdGenerator configurations, mapped by config name.
setFlakeIdGeneratorConfigs(Map<String, FlakeIdGeneratorConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setFlushSequences(Queue<WriteBehindStore.Sequence>) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
setFreeNativeMemory(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
setFreePhysical(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
setFsync(boolean) - Method in class com.hazelcast.config.HotRestartConfig
Sets whether disk write should be followed by an fsync() system call.
setFsync(boolean) - Method in class com.hazelcast.internal.config.HotRestartConfigReadOnly
 
setFunctionClassName(String) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
setFunctionImplementation(SplitBrainProtectionFunction) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
setGcpConfig(GcpConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets configuration to connect nodes in GCP environment.
setGcpConfig(GcpConfig) - Method in class com.hazelcast.config.JoinConfig
 
setGcpConfig(GcpConfig) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the GcpConfig used by the discovery mechanism for this WAN publisher.
setGcStats(LocalGCStats) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
SetGetAllCodec - Class in com.hazelcast.client.impl.protocol.codec
Return the all elements of this collection
SetGetAllCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetGetAllCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetGetAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
SetGetAllMessageTask
SetGetAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetGetAllMessageTask
 
setGetHits(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
setGetMisses(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
setGlobalOrderingEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
Enable global ordering (all nodes listening to the same topic get their messages in the same order), or disable it (nodes get the messages in the order that the messages are published).
setGlobalOrderingEnabled(boolean) - Method in class com.hazelcast.internal.config.TopicConfigReadOnly
 
setGlobalSerializerConfig(GlobalSerializerConfig) - Method in class com.hazelcast.config.SerializationConfig
 
setGroups(Collection<CPGroupInfo>) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
setGroupSize(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the number of CP members to form CP groups.
setGroupType(PartitionGroupConfig.MemberGroupType) - Method in class com.hazelcast.config.PartitionGroupConfig
Sets the MemberGroupType.
setHasBackup(boolean) - Method in class com.hazelcast.map.impl.MapKeyLoader
Sets if this map is configured with at least one backup.
setHasRunningCleanup(CachePartitionSegment) - Method in class com.hazelcast.cache.impl.eviction.CacheClearExpiredRecordsTask
 
setHasRunningCleanup(T) - Method in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
setHasRunningCleanup(PartitionContainer) - Method in class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
 
setHasRunningCleanup(boolean) - Method in class com.hazelcast.map.impl.PartitionContainer
 
setHazelcast(HazelcastInstance) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
setHazelcast(HazelcastInstance) - Method in class com.hazelcast.console.ConsoleApp
 
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.cache.impl.journal.DeserializingEventJournalCacheEvent
 
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.cluster.impl.MemberImpl
 
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.console.Echo
 
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.console.SimulateLoadTask
 
setHazelcastInstance(HazelcastInstance) - Method in interface com.hazelcast.core.HazelcastInstanceAware
Gets the HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.executor.impl.RunnableAdapter
 
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.internal.journal.DeserializingEntry
 
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
setHazelcastInstance(HazelcastInstance) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.map.impl.journal.DeserializingEventJournalMapEvent
 
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
 
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledFutureProxy
 
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.splitbrainprotection.impl.AbstractPingAwareSplitBrainProtectionFunction
 
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
 
setHead(long) - Method in interface com.hazelcast.map.impl.querycache.accumulator.Accumulator
Tries to set head of this accumulator to the supplied sequence and returns true, if that sequence is still exist in this accumulator.
setHead(long) - Method in class com.hazelcast.map.impl.querycache.accumulator.BasicAccumulator
 
setHead(long) - Method in interface com.hazelcast.map.impl.querycache.accumulator.CyclicBuffer
Sets head of this buffer to the supplied sequence and returns true, if that sequence is still in this buffer.
setHead(long) - Method in class com.hazelcast.map.impl.querycache.accumulator.DefaultCyclicBuffer
 
setHeadSequence(long) - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
 
setHeadSequence(long) - Method in interface com.hazelcast.ringbuffer.impl.Ringbuffer
Sets the head sequence.
setHeadSequence(long) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
Sets the head sequence.
setHeadSequence(long) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Sets the head sequence.
setHeapCost(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
setHeapCost(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
setHitCount(long) - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
Sets the hit count of this stats to the given hit count.
setHitCount(long) - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Sets the hit count to the given value.
setHits(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
setHits(long) - Method in interface com.hazelcast.map.impl.record.Record
 
setHits(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
 
setHits(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
setHits(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
setHits(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
setHits(long) - Method in class com.hazelcast.multimap.impl.MultiMapValue
 
setHits(long) - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
setHits(long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
setHits(long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
setHits(long) - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
setHits(long) - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
setHits(long) - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
setHits(long) - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
setHostHeader(String) - Method in class com.hazelcast.config.AwsConfig
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.AbstractCacheConfig
Sets the HotRestartConfig for this CacheConfiguration
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the HotRestartConfig for this CacheSimpleConfig
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.MapConfig
Sets the HotRestartConfig for this MapConfig
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setHotRestartPersistenceConfig(HotRestartPersistenceConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setHotRestartPersistenceConfig(HotRestartPersistenceConfig) - Method in class com.hazelcast.config.Config
Sets the Hot Restart configuration.
setHotRestartPersistenceConfig(HotRestartPersistenceConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setHotRestartState(HotRestartState) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
setIamRole(String) - Method in class com.hazelcast.config.AwsConfig
setIcmpFailureDetectorConfig(IcmpFailureDetectorConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setIcmpFailureDetectorConfig(IcmpFailureDetectorConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
setIcmpFailureDetectorConfig(IcmpFailureDetectorConfig) - Method in class com.hazelcast.config.NetworkConfig
setId(long) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
setId(long) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
setIdAttribute(String, boolean) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
setIdAttributeNode(Attr, boolean) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
setIdAttributeNS(String, String, boolean) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
setIdleMaxParkNs(long) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the maximum duration in nanoseconds that the WAN replication thread will be parked if there are no events to replicate.
setIdleMinParkNs(long) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the minimum duration in nanoseconds that the WAN replication thread will be parked if there are no events to replicate.
setIdOffset(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets the offset that will be added to the returned IDs.
setIdOffset(long) - Method in class com.hazelcast.internal.config.FlakeIdGeneratorConfigReadOnly
 
setIfEqualOrGreaterThan(AtomicLong, long) - Static method in class com.hazelcast.internal.util.ConcurrencyUtil
 
setImplementation(Data) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
setImplementation(Object) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
Sets the implementation of WanReplicationPublisher.
setImplementation(CachePartitionLostListener) - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
 
setImplementation(ICredentialsFactory) - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
setImplementation(Object) - Method in class com.hazelcast.config.CustomWanPublisherConfig
 
setImplementation(EventListener) - Method in class com.hazelcast.config.EntryListenerConfig
 
setImplementation(EntryListener) - Method in class com.hazelcast.config.EntryListenerConfig
 
setImplementation(Serializer) - Method in class com.hazelcast.config.GlobalSerializerConfig
 
setImplementation(ItemListener) - Method in class com.hazelcast.config.ItemListenerConfig
 
setImplementation(EventListener) - Method in class com.hazelcast.config.ListenerConfig
Sets the EventListener implementation.
setImplementation(Object) - Method in class com.hazelcast.config.LoginModuleConfig
Deprecated.
setImplementation(MapPartitionLostListener) - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
 
setImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfig
Sets the map store implementation object
setImplementation(MemberAddressProvider) - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
setImplementation(IPermissionPolicy) - Method in class com.hazelcast.config.PermissionPolicyConfig
 
setImplementation(Predicate) - Method in class com.hazelcast.config.PredicateConfig
Sets the Predicate implementation.
setImplementation(SecurityInterceptor) - Method in class com.hazelcast.config.SecurityInterceptorConfig
 
setImplementation(Serializer) - Method in class com.hazelcast.config.SerializerConfig
Sets the serializer implementation instance.
setImplementation(Object) - Method in class com.hazelcast.config.ServiceConfig
 
setImplementation(Object) - Method in class com.hazelcast.config.SocketInterceptorConfig
Sets the SocketInterceptor implementation object.
setImplementation(SplitBrainProtectionListener) - Method in class com.hazelcast.config.SplitBrainProtectionListenerConfig
 
setImplementation(Object) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
No-op method as the implementation cannot be changed for this publisher.
setImplementation(Object) - Method in class com.hazelcast.config.WanConsumerConfig
Sets the implementation for this WAN consumer.
setImplementation(EventListener) - Method in class com.hazelcast.internal.config.CachePartitionLostListenerConfigReadOnly
 
setImplementation(CachePartitionLostListener) - Method in class com.hazelcast.internal.config.CachePartitionLostListenerConfigReadOnly
 
setImplementation(EntryListener) - Method in class com.hazelcast.internal.config.EntryListenerConfigReadOnly
 
setImplementation(EventListener) - Method in class com.hazelcast.internal.config.EntryListenerConfigReadOnly
 
setImplementation(ItemListener) - Method in class com.hazelcast.internal.config.ItemListenerConfigReadOnly
 
setImplementation(EventListener) - Method in class com.hazelcast.internal.config.ItemListenerConfigReadOnly
 
setImplementation(EventListener) - Method in class com.hazelcast.internal.config.ListenerConfigReadOnly
 
setImplementation(EventListener) - Method in class com.hazelcast.internal.config.MapPartitionLostListenerConfigReadOnly
 
setImplementation(MapPartitionLostListener) - Method in class com.hazelcast.internal.config.MapPartitionLostListenerConfigReadOnly
 
setImplementation(Object) - Method in class com.hazelcast.internal.config.MapStoreConfigReadOnly
 
setImplementation(Predicate) - Method in class com.hazelcast.internal.config.PredicateConfigReadOnly
 
setIncludeValue(boolean) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
setIncludeValue(boolean) - Method in class com.hazelcast.config.EntryListenerConfig
 
setIncludeValue(boolean) - Method in class com.hazelcast.config.ItemListenerConfig
 
setIncludeValue(boolean) - Method in class com.hazelcast.config.QueryCacheConfig
Set true to enable value caching, otherwise set false
setIncludeValue(boolean) - Method in class com.hazelcast.internal.config.EntryListenerConfigReadOnly
 
setIncludeValue(boolean) - Method in class com.hazelcast.internal.config.ItemListenerConfigReadOnly
 
setIncludeValue(boolean) - Method in class com.hazelcast.internal.config.QueryCacheConfigReadOnly
 
setIncrHits(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
setIncrMisses(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
setIndexConfigs(List<IndexConfig>) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
setIndexConfigs(List<IndexConfig>) - Method in class com.hazelcast.config.MapConfig
 
setIndexConfigs(List<IndexConfig>) - Method in class com.hazelcast.config.QueryCacheConfig
 
setIndexConfigs(List<IndexConfig>) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setIndexConfigs(List<IndexConfig>) - Method in class com.hazelcast.internal.config.QueryCacheConfigReadOnly
 
setIndexedQueryCount(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
Sets the indexed query count of this stats to the given indexed query count value.
setIndexStats(Map<String, LocalIndexStatsImpl>) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
Sets the per-index stats of this map stats to the given per-index stats.
setInfo(AccumulatorInfo) - Method in class com.hazelcast.map.impl.querycache.publisher.EventPublisherAccumulatorProcessor
 
setInfoList(List<AccumulatorInfo>) - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
 
setInitialBackoffMillis(int) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
 
setInitialCPMembers(List<CPMemberInfo>) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
setInitializationCommitIndices(Set<Long>) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
setInitializationStatus(MetadataRaftGroupManager.MetadataRaftGroupInitStatus) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
setInitializedCPMembers(Collection<CPMemberInfo>) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
setInitialLoadMode(String) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
setInitialLoadMode(MapStoreConfig.InitialLoadMode) - Method in class com.hazelcast.config.MapStoreConfig
Sets the initial load mode.
setInitialLoadMode(MapStoreConfig.InitialLoadMode) - Method in class com.hazelcast.internal.config.MapStoreConfigReadOnly
 
setInitialOutputBufferSize(int) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
setInitialOutputBufferSize(int) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
setInitialPartitionVersion(int) - Method in class com.hazelcast.internal.partition.MigrationInfo
 
setInitialPublisherState(WanPublisherState) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the initial publisher state.
setInitialState(PartitionTableView) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
Sets the initial partition table and state version.
setInMemoryFormat(String) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheConfig
Data type that will be used to store records in this ICache.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the InMemory Format for this ICache.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.MapConfig
Binary type that will be used for storing records.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.NearCacheConfig
Sets the data type used to store entries.
setInMemoryFormat(String) - Method in class com.hazelcast.config.NearCacheConfig
 
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.QueryCacheConfig
Sets memory format of values of entries in QueryCache.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.ReplicatedMapConfig
Data type used to store entries.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.RingbufferConfig
Sets the in-memory format.
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.internal.config.NearCacheConfigReadOnly
 
setInMemoryFormat(String) - Method in class com.hazelcast.internal.config.NearCacheConfigReadOnly
 
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.internal.config.QueryCacheConfigReadOnly
 
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.internal.config.ReplicatedMapConfigReadOnly
 
setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.internal.config.RingbufferConfigReadOnly
 
setInnerClassDefinitions(Map<String, byte[]>) - Method in class com.hazelcast.internal.usercodedeployment.impl.ClassData
 
setInsertCount(long) - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
Sets the insert count of this stats to the given insert count.
setInsertCount(long) - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Sets the insert count to the given value.
setInstanceName(String) - Method in class com.hazelcast.client.config.ClientConfig
 
setInstanceName(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setInstanceName(String) - Method in class com.hazelcast.config.Config
Sets the instance name uniquely identifying the hazelcast instance created by this configuration.
setInstanceName(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.EndpointConfig
 
setInterfaces(Collection<String>) - Method in class com.hazelcast.config.InterfacesConfig
Adds a collection of interfaces.
setInterfaces(Collection<String>) - Method in class com.hazelcast.config.MemberGroupConfig
Sets the interfaces that are part of a group.
setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.NetworkConfig
 
setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setInternal(long, TimeUnit, Long, TimeUnit, Object, Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
setInternal(long, TimeUnit, Long, TimeUnit, Object, Object) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
setInternal(Object, Data, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
setIntervalMilliseconds(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
setIntervalMilliseconds(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Sets the time in milliseconds between each ping This value can not be smaller than 1000 milliseconds
setInvalidateOnChange(boolean) - Method in class com.hazelcast.config.NearCacheConfig
Sets if Near Cache entries are invalidated when the entries in the backing data structure are changed (updated or removed).
setInvalidateOnChange(boolean) - Method in class com.hazelcast.internal.config.NearCacheConfigReadOnly
 
setInvalidationSequence(long) - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
setInvalidationSequence(long) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecord
 
setInvocationTime(Operation, long) - Static method in class com.hazelcast.spi.impl.operationservice.OperationAccessor
Sets the invocation time for the Operation.
setInvocationTimeoutMillis(long) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocation
 
SetIsEmptyCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns true if this set contains no elements.
SetIsEmptyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetIsEmptyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetIsEmptyMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
SetIsEmptyMessageTask
SetIsEmptyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetIsEmptyMessageTask
 
setIsOldValueAvailable(boolean) - Method in class com.hazelcast.cache.impl.CacheEventContext
 
setItemId(long) - Method in class com.hazelcast.collection.impl.queue.QueueItem
 
setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.CollectionConfig
Sets the list of ItemListenerConfigs.
setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.QueueConfig
Set the list of item listener configurations for this queue.
setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.internal.config.ListConfigReadOnly
 
setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.internal.config.QueueConfigReadOnly
 
setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.internal.config.SetConfigReadOnly
 
setIterationCount(int) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setIterationType(IterationType) - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
 
setIterationType(PagingPredicate, IterationType) - Static method in class com.hazelcast.query.PagingPredicateAccessor
 
setJaasAuthenticationConfig(JaasAuthenticationConfig) - Method in class com.hazelcast.config.security.RealmConfig
 
setJarPaths(List<String>) - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
String jarPath is searched in following order: 1.
setJavaSerializationFilterConfig(JavaSerializationFilterConfig) - Method in class com.hazelcast.config.SerializationConfig
Allows to configure deserialization protection filter.
setJDKCompatible(boolean) - Method in class com.hazelcast.config.cp.SemaphoreConfig
Sets JDK compatibility mode of CP ISemaphore
setJitter(double) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
At each iteration calculated back-off is randomized via following method Random(-jitter * current_backoff, jitter * current_backoff)
setJmxEnabled(boolean) - Method in class com.hazelcast.config.MetricsConfig
Enables metrics exposure through JMX.
setJoin(JoinConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setJoin(JoinConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
setJoin(JoinConfig) - Method in class com.hazelcast.config.NetworkConfig
 
setKeepAlive(boolean) - Method in class com.hazelcast.client.config.SocketOptions
Enable/disable SO_KEEPALIVE socket option.
setKey(byte[]) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setKey(Object) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
setKey(Data) - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
setKey(Data) - Method in interface com.hazelcast.map.impl.record.Record
 
setKey(K) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
setKey(Data) - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
 
setKey(Data) - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
setKey(K) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
setKey(K) - Method in class com.hazelcast.spi.impl.merge.AbstractMergingEntryImpl
 
setKey(Data) - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
setKey(Data) - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
setKey(Data) - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
setKey(Object) - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
setKeyClassName(String) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setKeyMetadata(Object) - Method in class com.hazelcast.query.impl.Metadata
 
setKeySize(int) - Method in class com.hazelcast.config.EncryptionAtRestConfig
Sets the size (in bits) of the Hot Restart Store-level encryption key (non-positive value implies falling back to the cipher-specific default key length).
setKeyType(Class<K>) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setKeyType(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the key type for this ICache.
setKeyType(String) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setKubernetesConfig(KubernetesConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets configuration to connect nodes in Kubernetes environment.
setKubernetesConfig(KubernetesConfig) - Method in class com.hazelcast.config.JoinConfig
 
setKubernetesConfig(KubernetesConfig) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the KubernetesConfig used by the discovery mechanism for this WAN publisher.
setLabels(Set<String>) - Method in class com.hazelcast.client.config.ClientConfig
Set labels for the client.
setLastAccessTime(long) - Method in class com.hazelcast.cache.impl.CacheEventContext
 
setLastAccessTime(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Sets the cache last access time as atomic if the given time is bigger than it.
setLastAccessTime(long) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
 
setLastAccessTime(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
setLastAccessTime(long) - Method in interface com.hazelcast.map.impl.record.Record
 
setLastAccessTime(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
 
setLastAccessTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
setLastAccessTime(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
setLastAccessTime(long) - Method in class com.hazelcast.monitor.impl.LocalRecordStoreStatsImpl
 
setLastAccessTime(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
setLastAccessTime(long) - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Increases the number of hits of the locally owned entries of this partition.
setLastAccessTime(long) - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
setLastAccessTime(long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
setLastAccessTime(long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
setLastAccessTime(long) - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
setLastAccessTime(long) - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
setLastAccessTime(long) - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
setLastAccessTime(long) - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
setLastCleanupTime(long) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
 
setLastCleanupTime(long) - Method in class com.hazelcast.map.impl.PartitionContainer
 
setLastCleanupTimeCopy(long) - Method in class com.hazelcast.map.impl.PartitionContainer
 
setLastConsistencyCheckResults(Map<String, ConsistencyCheckResult>) - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
setLastStoredTime(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
setLastStoredTime(long) - Method in interface com.hazelcast.map.impl.record.Record
 
setLastStoredTime(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
 
setLastStoredTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
setLastStoredTime(long) - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
setLastSyncStats(Map<String, WanSyncStats>) - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
setLastTableIndex(List, int) - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
setLastTableIndex(List, int) - Method in class com.hazelcast.map.impl.iterator.AbstractMapPartitionIterator
 
setLastTableIndex(List<Data>, int) - Method in class com.hazelcast.map.impl.iterator.AbstractMapQueryPartitionIterator
 
setLastUpdateTime(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Sets the cache last update time as atomic if the given time is bigger than it.
setLastUpdateTime(long) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
 
setLastUpdateTime(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
setLastUpdateTime(long) - Method in interface com.hazelcast.map.impl.record.Record
 
setLastUpdateTime(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
 
setLastUpdateTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
setLastUpdateTime(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
setLastUpdateTime(long) - Method in class com.hazelcast.monitor.impl.LocalRecordStoreStatsImpl
 
setLastUpdateTime(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
setLastUpdateTime(long) - Method in interface com.hazelcast.monitor.LocalRecordStoreStats
Increases the number of hits of the locally owned entries of this partition.
setLastUpdateTime(long) - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
setLastUpdateTime(long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
setLastUpdateTime(long) - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
setLastUpdateTime(long) - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
setLastUpdateTime(long) - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
setLdapAuthenticationConfig(LdapAuthenticationConfig) - Method in class com.hazelcast.config.security.RealmConfig
 
setLeaderElectionTimeoutInMillis(long) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setLeaderHeartbeatPeriodInMillis(long) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setLicenseKey(String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setLicenseKey(String) - Method in class com.hazelcast.config.Config
Sets the license key for this hazelcast instance.
setLicenseKey(String) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
setLicenseKey(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
SetLicenseOperation - Class in com.hazelcast.internal.management.operation
Operation to update license at runtime.
SetLicenseOperation() - Constructor for class com.hazelcast.internal.management.operation.SetLicenseOperation
 
SetLicenseOperation(String) - Constructor for class com.hazelcast.internal.management.operation.SetLicenseOperation
 
setLingerSeconds(int) - Method in class com.hazelcast.client.config.SocketOptions
Enable/disable SO_LINGER with the specified linger time in seconds If set to a value of 0 or less then it is disabled.
setListConfigs(Map<String, ListConfig>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setListConfigs(Map<String, ListConfig>) - Method in class com.hazelcast.config.Config
Sets the map of IList configurations, mapped by config name.
setListConfigs(Map<String, ListConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.client.config.ClientConfig
Sets all ListenerConfig's
setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setListenerConfigs(List<ListenerConfigHolder>) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.Config
Sets the list of EventListener configurations.
setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.ReplicatedMapConfig
 
setListenerConfigs(List<SplitBrainProtectionListenerConfig>) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.internal.config.ReplicatedMapConfigReadOnly
 
setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setListenerConfigurations() - Method in class com.hazelcast.config.AbstractCacheConfig
 
setListenerConfigurations(Set<CacheEntryListenerConfiguration<K, V>>) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setLite(boolean) - Method in class com.hazelcast.internal.management.TimedMemberState
 
setLiteMember(boolean) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setLiteMember(boolean) - Method in class com.hazelcast.config.Config
Sets the flag to indicate if this member is a lite member.
setLiteMember(boolean) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setLoadBalancer(LoadBalancer) - Method in class com.hazelcast.client.config.ClientConfig
Sets the LoadBalancer
setLoaded(boolean) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
setLoaded(boolean) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
setLocal(boolean) - Method in class com.hazelcast.config.EntryListenerConfig
 
setLocal(boolean) - Method in class com.hazelcast.internal.config.EntryListenerConfigReadOnly
 
setLocalMemoryStats(LocalMemoryStats) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
setLocalPublisherStatsMap(Map<String, LocalWanPublisherStats>) - Method in class com.hazelcast.monitor.impl.LocalWanStatsImpl
 
setLocalUpdatePolicy(NearCacheConfig.LocalUpdatePolicy) - Method in class com.hazelcast.config.NearCacheConfig
Sets the NearCacheConfig.LocalUpdatePolicy of this Near Cache.
setLocalUpdatePolicy(NearCacheConfig.LocalUpdatePolicy) - Method in class com.hazelcast.internal.config.NearCacheConfigReadOnly
 
setLockAcquireLimit(int) - Method in class com.hazelcast.config.cp.FencedLockConfig
Sets the number of lock acquires a lock holder can perform.
setLockConfigs(Map<String, FencedLockConfig>) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the map of FencedLock configurations, mapped by config name.
setLockedEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
setLockedEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
setLogger(ILogger) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
 
setLoginContext(LoginContext) - Method in interface com.hazelcast.client.impl.ClientEndpoint
 
setLoginContext(LoginContext) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
setLoginModuleConfigs(List<LoginModuleConfig>) - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
 
setLoopbackModeEnabled(boolean) - Method in class com.hazelcast.config.MulticastConfig
Enables or disables the loopback mode in the multicast discovery mechanism.
setMajorCount(long) - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
 
setMajorTime(long) - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
 
setManagedContext(ManagedContext) - Method in class com.hazelcast.client.config.ClientConfig
setManagedContext(ManagedContext) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setManagedContext(ManagedContext) - Method in class com.hazelcast.config.Config
Sets the external managed context.
setManagedContext(ManagedContext) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setManagedContext(ManagedContext) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
setManagedContext(ManagedContext) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
setManagementCenterConfig(ManagementCenterConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setManagementCenterConfig(ManagementCenterConfig) - Method in class com.hazelcast.config.Config
Sets the management center configuration for this hazelcast instance.
setManagementCenterConfig(ManagementCenterConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setManagementEnabled(CacheConfig, String, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
setManagementEnabled(CacheConfig, String, boolean) - Method in interface com.hazelcast.cache.impl.ICacheService
 
setManagementEnabled(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
Sets whether or not management is enabled on this cache.
setManagementEnabled(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
Sets whether management is enabled on a cache.
setManagementEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets management to enabled or disabled for this ICache.
setManagementEnabled(boolean) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setManagementEnabled(boolean) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setManagerPrefix(String) - Method in class com.hazelcast.config.CacheConfig
Sets the manager prefix of the ICache.
setManagerPrefix(String) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setMapConfig(MapConfig) - Method in class com.hazelcast.map.impl.MapContainer
 
setMapConfigs(Map<String, MapConfig>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setMapConfigs(Map<String, MapConfig>) - Method in class com.hazelcast.config.Config
Sets the map of IMap configurations, mapped by config name.
setMapConfigs(Map<String, MapConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setMapContainer(MapContainer) - Method in class com.hazelcast.map.impl.operation.MapOperation
 
setMapEvictionPolicy(MapEvictionPolicy) - Method in class com.hazelcast.config.MapConfig
Sets custom eviction policy implementation for this map.
setMapEvictionPolicy(MapEvictionPolicy) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setMapOperationProvider(MapOperationProvider) - Method in class com.hazelcast.map.impl.MapKeyLoader
 
setMapService(MapService) - Method in class com.hazelcast.map.impl.operation.MapOperation
 
setMapStoreConfig(MapStoreConfig) - Method in class com.hazelcast.config.MapConfig
Sets the map store configuration
setMapStoreConfig(MapStoreConfig) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setMaster(boolean) - Method in class com.hazelcast.internal.management.TimedMemberState
 
setMaster(Address) - Method in class com.hazelcast.internal.partition.MigrationInfo
 
setMaster(Address) - Method in class com.hazelcast.internal.partition.PartitionRuntimeState
 
setMasterAddressToJoin(Address) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
setMasterTime(long) - Method in class com.hazelcast.internal.cluster.impl.ClusterClockImpl
Calculate and set the cluster clock diff.
setMax(E, AtomicLongFieldUpdater<E>, long) - Static method in class com.hazelcast.internal.util.ConcurrencyUtil
Atomically sets the max value.
setMaxAge(long) - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
setMaxAppendRequestBackoff() - Method in class com.hazelcast.cp.internal.raft.impl.state.FollowerState
Sets the flag for append request backoff to max value.
setMaxAttempts(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
setMaxAttempts(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Set the max ping attempts before suspecting a member
setMaxBackoffMillis(int) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
When backoff reaches this upper bound, it does not increase any more.
setMaxBatch(int) - Method in class com.hazelcast.map.impl.MapKeyLoader
Sets the maximum size of a batch of loaded keys sent to the partition owner for value loading.
setMaxConcurrentInvocations(int) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the maximum number of WAN event batches being sent to the target cluster concurrently.
setMaxConcurrentReplicationTargets(int) - Method in class com.hazelcast.config.CRDTReplicationConfig
Sets the maximum number of target members that we replicate the CRDT states to in one period.
setMaxHeap(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
setMaxIdle(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
setMaxIdle(long) - Method in interface com.hazelcast.map.impl.record.Record
 
setMaxIdle(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
 
setMaxIdle(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
setMaxIdle(Long) - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
setMaxIdleSeconds(int) - Method in class com.hazelcast.config.MapConfig
Maximum number of seconds for each entry to stay idle in the map.
setMaxIdleSeconds(int) - Method in class com.hazelcast.config.NearCacheConfig
Set the maximum number of seconds each entry can stay in the Near Cache as untouched (not-read).
setMaxIdleSeconds(int) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setMaxIdleSeconds(int) - Method in class com.hazelcast.internal.config.NearCacheConfigReadOnly
 
setMaximumSizePolicy(EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.config.EvictionConfig
Sets the EvictionConfig.MaxSizePolicy of this eviction configuration.
setMaximumSizePolicy(EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.internal.config.EvictionConfigReadOnly
 
setMaxMetadata(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
setMaxMissedLeaderHeartbeatCount(int) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setMaxNativeMemory(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
setMaxSize(int) - Method in class com.hazelcast.config.CollectionConfig
Sets the maximum size for the collection.
setMaxSize(int) - Method in class com.hazelcast.config.QueueConfig
Sets the maximum size of the Queue.
setMaxSize(int) - Method in class com.hazelcast.internal.config.ListConfigReadOnly
 
setMaxSize(int) - Method in class com.hazelcast.internal.config.QueueConfigReadOnly
 
setMaxSize(int) - Method in class com.hazelcast.internal.config.SetConfigReadOnly
 
setMaxSize(int) - Method in class com.hazelcast.map.impl.MapKeyLoader
Sets the configured maximum entry count per node.
setMaxSizeConfig(MaxSizeConfig) - Method in class com.hazelcast.config.MapConfig
 
setMaxSizeConfig(MaxSizeConfig) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setMaxSizePolicy(MaxSizeConfig.MaxSizePolicy) - Method in class com.hazelcast.config.MaxSizeConfig
Ses the maximum size policy of the map.
setMaxSizePolicy(MaxSizeConfig.MaxSizePolicy) - Method in class com.hazelcast.internal.config.MaxSizeConfigReadOnly
 
setMaxTargetEndpoints(int) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the maximum number of endpoints that WAN will connect to when using a discovery mechanism to define endpoints.
SetMBean - Class in com.hazelcast.internal.jmx
Management bean for ISet
SetMBean(ISet, ManagementService) - Constructor for class com.hazelcast.internal.jmx.SetMBean
 
setMcEnabled(boolean) - Method in class com.hazelcast.config.MetricsConfig
Enables exposing metrics to Hazelcast Management Center.
setMemberAddressProviderConfig(MemberAddressProviderConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setMemberAddressProviderConfig(MemberAddressProviderConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
setMemberAddressProviderConfig(MemberAddressProviderConfig) - Method in class com.hazelcast.config.NetworkConfig
 
setMemberAttributeConfig(MemberAttributeConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setMemberAttributeConfig(MemberAttributeConfig) - Method in class com.hazelcast.config.Config
Sets the member attribute configuration.
setMemberAttributeConfig(MemberAttributeConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setMemberEndpointConfig(ServerSocketEndpointConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
Sets the server socket endpoint config for MEMBER protocol.
setMemberGroupConfigs(Collection<MemberGroupConfig>) - Method in class com.hazelcast.config.PartitionGroupConfig
Adds a MemberGroupConfig.
setMemberList(List<String>) - Method in class com.hazelcast.internal.management.TimedMemberState
 
setMemberListJoinVersion(int) - Method in class com.hazelcast.cluster.impl.MemberImpl
 
setMemberRealm(String) - Method in class com.hazelcast.config.SecurityConfig
 
setMemberRealm(String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
setMemberRealmConfig(String, RealmConfig) - Method in class com.hazelcast.config.SecurityConfig
 
setMemberRealmConfig(String, RealmConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
setMembers(List<String>) - Method in class com.hazelcast.config.TcpIpConfig
Sets the well known members.
setMembers(Collection<CPMemberInfo>) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
setMembers(long, long, Collection<CPMemberInfo>) - Method in class com.hazelcast.spi.impl.operationservice.impl.RaftInvocationContext
 
setMembersCommitIndex(long) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
setMembershipChangeSchedule(MembershipChangeSchedule) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
setMemberState(MemberStateImpl) - Method in class com.hazelcast.internal.management.TimedMemberState
 
setMemberStateSafe(boolean) - Method in class com.hazelcast.monitor.impl.MemberPartitionStateImpl
 
setMemcacheEndpointConfig(ServerSocketEndpointConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
Sets the server socket endpoint config for memcache protocol.
setMemcacheProtocolConfig(MemcacheProtocolConfig) - Method in class com.hazelcast.config.NetworkConfig
 
setMemMgr(MemoryManager) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
setMemory(long, long, byte) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
 
setMemory(long, long, byte) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
 
setMemory(long, long, byte) - Method in interface com.hazelcast.internal.memory.MemoryAccessor
Sets memory with given value from specified address as given size.
setMemoryCost(long) - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
Sets the memory cost of this stats to the given memory cost value.
setMemoryCost(long) - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Sets the memory cost to the given value.
setMergePolicy(String) - Method in class com.hazelcast.config.WanReplicationRef
Sets the merge policy sent to the WAN replication target to merge replicated entries with existing target entries.
setMergePolicy(String) - Method in class com.hazelcast.internal.config.WanReplicationRefReadOnly
 
setMergePolicy(SplitBrainMergePolicy) - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.AbstractBasicConfig
Sets the MergePolicyConfig for this data structure.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.CacheConfig
Sets the MergePolicyConfig for this map.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the MergePolicyConfig for this map.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Sets the MergePolicyConfig for the scheduler.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.CollectionConfig
Sets the MergePolicyConfig for the collection.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.MapConfig
Sets the MergePolicyConfig for this map.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.MultiMapConfig
Sets the MergePolicyConfig for this MultiMap.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.QueueConfig
Sets the MergePolicyConfig for this queue.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.ReplicatedMapConfig
Sets the MergePolicyConfig for this replicated map.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.RingbufferConfig
Sets the MergePolicyConfig for this ringbuffer.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the MergePolicyConfig for the scheduler.
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.internal.config.CardinalityEstimatorConfigReadOnly
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.internal.config.ListConfigReadOnly
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.internal.config.MultiMapConfigReadOnly
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.internal.config.QueueConfigReadOnly
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.internal.config.ReplicatedMapConfigReadOnly
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.internal.config.RingbufferConfigReadOnly
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.internal.config.ScheduledExecutorConfigReadOnly
 
setMergePolicyConfig(MergePolicyConfig) - Method in class com.hazelcast.internal.config.SetConfigReadOnly
 
setMerkleTreeConfig(MerkleTreeConfig) - Method in class com.hazelcast.config.MapConfig
Sets the MerkleTreeConfig for this MapConfig
setMerkleTreeConfig(MerkleTreeConfig) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setMerkleTreesCost(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
setMerkleTreesCost(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
setMessageListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.ReliableTopicConfig
Sets the list of message listeners (listens for when messages are added or removed) for this topic.
setMessageListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.TopicConfig
Sets the list of message listeners (listens for when messages are added or removed) for this topic.
setMessageListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.internal.config.TopicConfigReadOnly
 
SetMessageTask - Class in com.hazelcast.cp.internal.datastructures.atomicref.client
Client message task for SetOp
SetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.client.SetMessageTask
 
setMessageType(int) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
setMetadata(Collection<Map.Entry<Integer, UUID>>, Collection<Map.Entry<String, List<Map.Entry<Integer, Long>>>>) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationMetaDataFetcher.MetadataHolder
 
setMetadata(Metadata) - Method in class com.hazelcast.map.impl.LazyMapEntry
 
setMetadata(Metadata) - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
setMetadata(Metadata) - Method in interface com.hazelcast.map.impl.record.Record
 
setMetadata(Record, Metadata) - Method in class com.hazelcast.map.impl.recordstore.JsonMetadataRecordStoreMutationObserver
 
setMetadataPolicy(MetadataPolicy) - Method in class com.hazelcast.config.MapConfig
Sets the metadata policy.
setMetadataSpacePercentage(float) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets the percentage of native memory space to be used to store metadata and internal memory structures by the native memory manager.
setMetricsConfig(MetricsConfig) - Method in class com.hazelcast.client.config.ClientConfig
Sets the metrics collection config.
setMetricsConfig(MetricsConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setMetricsConfig(MetricsConfig) - Method in class com.hazelcast.config.Config
Sets the metrics collection config.
setMetricsConfig(MetricsConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setMetricsForDataStructuresEnabled(boolean) - Method in class com.hazelcast.config.MetricsConfig
Sets whether statistics for data structures are added to metrics.
setMigrating() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionImpl
Sets migrating flag if it's not set already.
setMigrationInterceptor(MigrationInterceptor) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
setMigrationQueueSize(long) - Method in class com.hazelcast.monitor.impl.MemberPartitionStateImpl
 
setMinAge(long) - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
setMinBlockSize(int) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets the minimum memory block size, in bytes, to be served by native memory manager.
setMinimumClusterSize(int) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
setMinimumLevel(ProbeLevel) - Method in class com.hazelcast.config.MetricsConfig
Sets the minimum probe level to be collected.
setMinorCount(long) - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
 
setMinorTime(long) - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
 
setMissingCPMemberAutoRemovalSeconds(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the duration to wait before automatically removing a missing CP member from CP Subsystem.
setMulticastConfig(MulticastConfig) - Method in class com.hazelcast.config.JoinConfig
 
setMulticastGroup(String) - Method in class com.hazelcast.config.MulticastConfig
Sets the multicast group.
setMulticastPort(int) - Method in class com.hazelcast.config.MulticastConfig
Sets the multicast port.
setMulticastTimeoutSeconds(int) - Method in class com.hazelcast.config.MulticastConfig
Specifies the time in seconds that a node should wait for a valid multicast response from another node running in the network before declaring itself as master node and creating its own cluster.
setMulticastTimeToLive(int) - Method in class com.hazelcast.config.MulticastConfig
Sets the time to live for the multicast package; a value between 0..255.
setMultiMapConfigs(Map<String, MultiMapConfig>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setMultiMapConfigs(Map<String, MultiMapConfig>) - Method in class com.hazelcast.config.Config
Sets the map of MultiMap configurations, mapped by config name.
setMultiMapConfigs(Map<String, MultiMapConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setMultiplier(double) - Method in class com.hazelcast.client.config.ConnectionRetryConfig
 
setMultiThreadingEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
Enable multi-threaded message handling.
setMultiThreadingEnabled(boolean) - Method in class com.hazelcast.internal.config.TopicConfigReadOnly
 
setMutualAuthConfig(MCMutualAuthConfig) - Method in class com.hazelcast.config.ManagementCenterConfig
Sets the management center mutual auth config
setName(String) - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
Sets the name or name pattern for this config.
setName(String) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Sets the name or name pattern for this config.
setName(String) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
setName(String) - Method in class com.hazelcast.config.AbstractBasicConfig
Sets the name of this data structure.
setName(String) - Method in class com.hazelcast.config.AttributeConfig
Sets the name of the attribute extracted by the extractor.
setName(String) - Method in class com.hazelcast.config.CacheConfig
Sets the name of this ICache.
setName(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the name of this ICache.
setName(String) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Sets the name of the cardinality estimator.
setName(String) - Method in class com.hazelcast.config.CollectionConfig
Sets the name of this collection.
setName(String) - Method in class com.hazelcast.config.cp.FencedLockConfig
Sets the name of FencedLock
setName(String) - Method in class com.hazelcast.config.cp.SemaphoreConfig
Sets the name of CP ISemaphore
setName(String) - Method in class com.hazelcast.config.DurableExecutorConfig
Sets the name of the executor task.
setName(String) - Method in class com.hazelcast.config.EndpointConfig
 
setName(String) - Method in class com.hazelcast.config.ExecutorConfig
Sets the name of the executor task.
setName(String) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets the name or name pattern for this config.
setName(String) - Method in class com.hazelcast.config.IndexConfig
Sets name of the index.
setName(String) - Method in class com.hazelcast.config.MapConfig
Sets the name of the IMap
setName(String) - Method in class com.hazelcast.config.MultiMapConfig
Sets the name of this MultiMap.
setName(String) - Method in interface com.hazelcast.config.NamedConfig
 
setName(String) - Method in class com.hazelcast.config.NearCacheConfig
Sets the name of the Near Cache.
setName(String) - Method in class com.hazelcast.config.PermissionConfig
 
setName(String) - Method in class com.hazelcast.config.PNCounterConfig
Sets the name of the PN counter.
setName(String) - Method in class com.hazelcast.config.QueryCacheConfig
Sets the name of QueryCache.
setName(String) - Method in class com.hazelcast.config.QueueConfig
Set the name for this queue.
setName(String) - Method in class com.hazelcast.config.ReliableTopicConfig
Sets the name of the reliable topic.
setName(String) - Method in class com.hazelcast.config.ReplicatedMapConfig
Sets the name of this ReplicatedMap.
setName(String) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setName(String) - Method in class com.hazelcast.config.RingbufferConfig
Sets the name of the ringbuffer.
setName(String) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the name of the executor task.
setName(String) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setName(String) - Method in class com.hazelcast.config.ServiceConfig
 
setName(String) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
setName(String) - Method in class com.hazelcast.config.TopicConfig
Sets the name of the topic.
setName(String) - Method in class com.hazelcast.config.WanReplicationConfig
Sets the name of this WAN replication config.
setName(String) - Method in class com.hazelcast.config.WanReplicationRef
Sets the WAN replication reference name.
setName(String) - Method in class com.hazelcast.internal.config.AttributeConfigReadOnly
 
setName(String) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setName(String) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setName(String) - Method in class com.hazelcast.internal.config.CardinalityEstimatorConfigReadOnly
 
setName(String) - Method in class com.hazelcast.internal.config.DurableExecutorConfigReadOnly
 
setName(String) - Method in class com.hazelcast.internal.config.ExecutorConfigReadOnly
 
setName(String) - Method in class com.hazelcast.internal.config.FlakeIdGeneratorConfigReadOnly
 
setName(String) - Method in class com.hazelcast.internal.config.IndexConfigReadOnly
 
setName(String) - Method in class com.hazelcast.internal.config.ListConfigReadOnly
 
setName(String) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setName(String) - Method in class com.hazelcast.internal.config.MultiMapConfigReadOnly
 
setName(String) - Method in class com.hazelcast.internal.config.NearCacheConfigReadOnly
 
setName(String) - Method in class com.hazelcast.internal.config.PNCounterConfigReadOnly
 
setName(String) - Method in class com.hazelcast.internal.config.QueryCacheConfigReadOnly
 
setName(String) - Method in class com.hazelcast.internal.config.QueueConfigReadOnly
 
setName(String) - Method in class com.hazelcast.internal.config.ReplicatedMapConfigReadOnly
 
setName(String) - Method in class com.hazelcast.internal.config.ScheduledExecutorConfigReadOnly
 
setName(String) - Method in class com.hazelcast.internal.config.SetConfigReadOnly
 
setName(String) - Method in class com.hazelcast.internal.config.TopicConfigReadOnly
 
setName(String) - Method in class com.hazelcast.internal.config.WanReplicationRefReadOnly
 
setName(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
setName(String) - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
setNativeMemoryConfig(NativeMemoryConfig) - Method in class com.hazelcast.client.config.ClientConfig
 
setNativeMemoryConfig(NativeMemoryConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setNativeMemoryConfig(NativeMemoryConfig) - Method in class com.hazelcast.config.Config
Sets the native memory configuration for this hazelcast instance.
setNativeMemoryConfig(NativeMemoryConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.config.MapConfig
Sets the Near Cache configuration
setNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setNearCacheConfigMap(Map<String, NearCacheConfig>) - Method in class com.hazelcast.client.config.ClientConfig
Sets all NearCacheConfig's with the provided map
setNearCacheStats(NearCacheStats) - Method in class com.hazelcast.client.cache.impl.ClientCacheStatisticsImpl
 
setNearCacheStats(NearCacheStats) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
setNetworkConfig(ClientNetworkConfig) - Method in class com.hazelcast.client.config.ClientConfig
setNetworkConfig(NetworkConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setNetworkConfig(NetworkConfig) - Method in class com.hazelcast.config.Config
Sets the network configuration for this hazelcast instance.
setNetworkConfig(NetworkConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setNew(boolean) - Method in class com.hazelcast.internal.util.hashslot.impl.SlotAssignmentResultImpl
Sets if the last assignment invocation resulted in a new assignment or if there was an existing slot for the given parameters.
setNextRecordId(long) - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
 
setNextSequenceToReadFrom(long) - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
 
setNextTableIndexToReadFrom(int) - Method in class com.hazelcast.map.impl.query.ResultSegment
 
setNode(Node) - Method in interface com.hazelcast.internal.services.NodeAware
 
setNode(Node) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledRunnableAdapter
 
setNode(Node) - Method in class com.hazelcast.spi.impl.operationservice.BinaryOperationFactory
 
setNodeEngine(NodeEngine) - Method in class com.hazelcast.cp.internal.RaftOp
 
setNodeEngine(NodeEngine) - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
setNodeEntries(Set<EntryView<Data, Data>>) - Method in class com.hazelcast.map.impl.MerkleTreeNodeEntries
 
setNodeFilter(NodeFilter) - Method in class com.hazelcast.config.DiscoveryConfig
 
setNodeFilter(NodeFilter) - Method in class com.hazelcast.internal.config.DiscoveryConfigReadOnly
 
setNodeFilterClass(String) - Method in class com.hazelcast.config.DiscoveryConfig
 
setNodeFilterClass(String) - Method in class com.hazelcast.internal.config.DiscoveryConfigReadOnly
 
setNodeIdOffset(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets the offset that will be added to the node ID assigned to cluster member for this generator.
setNodeIdOffset(long) - Method in class com.hazelcast.internal.config.FlakeIdGeneratorConfigReadOnly
 
setNodeName(String) - Method in class com.hazelcast.internal.yaml.AbstractYamlNode
 
setNodeName(String) - Method in interface com.hazelcast.internal.yaml.MutableYamlNode
Sets the name of the node to the provided one
setNodeOrder(int) - Method in class com.hazelcast.map.impl.MerkleTreeNodeEntries
 
setNodeState(NodeState) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
setNodeValue(String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
setNormalPacketsRead(Counter) - Method in class com.hazelcast.internal.networking.nio.InboundHandlerWithCounters
 
setNotActiveExceptionSupplier(Supplier<RuntimeException>) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
setNotActiveExceptionSupplier(Supplier<RuntimeException>) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
setNullOrEmptyTarget(boolean) - Method in class com.hazelcast.query.impl.getters.ImmutableMultiResult
 
setNullOrEmptyTarget(boolean) - Method in class com.hazelcast.query.impl.getters.MultiResult
 
setNumberOfBackupAcks(int) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
Sets the setNumberOfAcks field.
setObject(Object) - Method in class com.hazelcast.multimap.impl.MultiMapRecord
 
setObjectName(Map<String, String>) - Method in class com.hazelcast.internal.jmx.HazelcastMBean
 
setOldValueRequired(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
If true, previously assigned values for the affected keys will be sent to this cache entry listener implementation.
setOldValueRequired(boolean) - Method in class com.hazelcast.internal.config.CacheSimpleEntryListenerConfigReadOnly
 
setOnJoinPermissionOperation(OnJoinPermissionOperationName) - Method in class com.hazelcast.config.SecurityConfig
 
setOnJoinPermissionOperation(OnJoinPermissionOperationName) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
SetOp - Class in com.hazelcast.cp.internal.datastructures.atomicref.operation
SetOp() - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.operation.SetOp
 
SetOp(String, Data, boolean) - Constructor for class com.hazelcast.cp.internal.datastructures.atomicref.operation.SetOp
 
SetOperation - Class in com.hazelcast.internal.longregister.operations
 
SetOperation() - Constructor for class com.hazelcast.internal.longregister.operations.SetOperation
 
SetOperation(String, long) - Constructor for class com.hazelcast.internal.longregister.operations.SetOperation
 
SetOperation - Class in com.hazelcast.map.impl.operation
 
SetOperation() - Constructor for class com.hazelcast.map.impl.operation.SetOperation
 
SetOperation(String, Data, Data) - Constructor for class com.hazelcast.map.impl.operation.SetOperation
 
setOperationName(String) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
setOperationResponseHandler(OperationResponseHandler) - Method in class com.hazelcast.spi.impl.operationservice.Operation
setOperationServiceBean(OperationServiceDTO) - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
 
setOperationStats(LocalOperationStats) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
setOperationTryCount(int) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterProxy
Sets the operation retry count for PN counter operations.
setOption(ChannelOption<T>, T) - Method in interface com.hazelcast.internal.networking.ChannelOptions
Sets an option value.
setOrderKey(int) - Method in class com.hazelcast.cache.impl.CacheEventContext
 
setOrigin(UUID) - Method in class com.hazelcast.cache.impl.CacheEventContext
 
setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Set outbound port definitions
setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.EndpointConfig
 
setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.NetworkConfig
 
setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Set outbond ports
setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.EndpointConfig
 
setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.NetworkConfig
 
setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setOutboundQueueSize(int) - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
setOutOfMemoryHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.client.HazelcastClient
Sets OutOfMemoryHandler to be used when an OutOfMemoryError is caught by Hazelcast Client threads.
setOutOfMemoryHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.core.Hazelcast
Sets OutOfMemoryHandler to be used when an OutOfMemoryError is caught by Hazelcast threads.
setOverrideJavaSerialization(boolean) - Method in class com.hazelcast.config.GlobalSerializerConfig
 
setOwnedEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
setOwnedEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
setOwnedEntryCount(long) - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
setOwnedEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
setOwnedEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
setOwnedEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
setOwnedItemCount(int) - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
setOwnerUuid(UUID) - Method in interface com.hazelcast.map.impl.tx.MapTxnOperation
 
setOwnerUuid(UUID) - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
 
setOwnerUuid(UUID) - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
 
setOwnerUuid(UUID) - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
 
setPackages(Collection<String>) - Method in class com.hazelcast.config.ClassFilter
 
setPacketType(Packet.Type) - Method in class com.hazelcast.internal.nio.Packet
Sets the packet type by updating the packet type bits in the flags bitfield.
setPage(int) - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
 
setPage(int) - Method in interface com.hazelcast.query.PagingPredicate
Sets the current page value.
setPageSize(int) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets the page size, in bytes, to be allocated by native memory manager as a single block.
setParallelism(int) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets the number of Hot Restart store instances to create for one Hazelcast instance.
setParallelMode(boolean) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Set the ICMP detector to run in parallel mode, independent from the other failure detectors.
setParent(JsonSchemaStructNode) - Method in class com.hazelcast.json.internal.JsonSchemaNode
Sets the parent of this node.
setParseDn(boolean) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setPartitionCount(int) - Method in class com.hazelcast.internal.management.dto.PartitionServiceBeanDTO
 
setPartitionGroupConfig(PartitionGroupConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setPartitionGroupConfig(PartitionGroupConfig) - Method in class com.hazelcast.config.Config
Sets the partition group configuration for this hazelcast instance.
setPartitionGroupConfig(PartitionGroupConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setPartitionId(int) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
setPartitionId(int) - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
setPartitionId(int) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecord
 
setPartitionId(int) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
setPartitionId(int) - Method in class com.hazelcast.spi.impl.operationservice.Operation
Sets the partition ID.
setPartitionIds(PartitionIdSet) - Method in class com.hazelcast.map.impl.query.AggregationResult
 
setPartitionIds(PartitionIdSet) - Method in class com.hazelcast.map.impl.query.QueryResult
 
setPartitionIds(PartitionIdSet) - Method in interface com.hazelcast.map.impl.query.Result
Sets the partition IDs of this result.
setPartitioningStrategy(PartitioningStrategy) - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
setPartitioningStrategy(PartitioningStrategy) - Method in class com.hazelcast.internal.config.PartitioningStrategyConfigReadOnly
 
setPartitioningStrategy(PartitioningStrategy) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
setPartitioningStrategy(PartitioningStrategy) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
setPartitioningStrategyClass(String) - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
setPartitioningStrategyClass(String) - Method in class com.hazelcast.internal.config.PartitioningStrategyConfigReadOnly
 
setPartitioningStrategyConfig(PartitioningStrategyConfig) - Method in class com.hazelcast.config.MapConfig
 
setPartitioningStrategyConfig(PartitioningStrategyConfig) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setPartitionLostListenerConfigs(List<CachePartitionLostListenerConfig>) - Method in class com.hazelcast.config.CacheConfig
Sets the WAN target replication reference.
setPartitionLostListenerConfigs(List<CachePartitionLostListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the PartitionLostListenerConfigs.
setPartitionLostListenerConfigs(List<MapPartitionLostListenerConfig>) - Method in class com.hazelcast.config.MapConfig
 
setPartitionLostListenerConfigs(List<CachePartitionLostListenerConfig>) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setPartitionLostListenerConfigs(List<CachePartitionLostListenerConfig>) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setPartitionLostListenerConfigs(List<MapPartitionLostListenerConfig>) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setPartitionReplicaVersions(int, ServiceNamespace, long[], int) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
 
setPartitionServiceBean(PartitionServiceBeanDTO) - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
 
setPartitionStrategy(PartitioningStrategy) - Method in class com.hazelcast.config.PartitioningStrategyConfig
Deprecated.
setPartitionStrategy(PartitioningStrategy) - Method in class com.hazelcast.internal.config.PartitioningStrategyConfigReadOnly
 
setPartitionVersionIncrement(int) - Method in class com.hazelcast.internal.partition.MigrationInfo
 
setPassword(String) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Sets the Java KeyStore password.
setPassword(String) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setPassword(String) - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
setPasswordAttribute(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setPath(File) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Sets the Java KeyStore file path.
SetPermission - Class in com.hazelcast.security.permission
 
SetPermission(String, String...) - Constructor for class com.hazelcast.security.permission.SetPermission
 
setPersistenceEnabled(boolean) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets whether CP Subsystem Persistence is enabled on this member.
setPersistentMemoryDirectory(String) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets the persistent memory directory (e.g.
setPersistWanReplicatedData(boolean) - Method in class com.hazelcast.config.WanConsumerConfig
 
setPNCounterConfigs(Map<String, PNCounterConfig>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setPNCounterConfigs(Map<String, PNCounterConfig>) - Method in class com.hazelcast.config.Config
Sets the map of PN counter configurations, mapped by config name.
setPNCounterConfigs(Map<String, PNCounterConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setPolicy(String) - Method in class com.hazelcast.config.MergePolicyConfig
Sets the classname of your SplitBrainMergePolicy.
setPolicy(String) - Method in class com.hazelcast.internal.config.MergePolicyConfigReadOnly
 
setPollingInterval(int) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Sets the polling interval (in seconds) for checking for changes in the KeyStore.
setPollingInterval(int) - Method in class com.hazelcast.config.VaultSecureStoreConfig
Sets the polling interval (in seconds) for checking for changes in Vault.
setPollOperation(boolean) - Method in class com.hazelcast.collection.impl.txnqueue.TxQueueItem
 
setPoolSize(int) - Method in class com.hazelcast.config.DurableExecutorConfig
Sets the number of executor threads per member for the executor.
setPoolSize(int) - Method in class com.hazelcast.config.ExecutorConfig
Sets the number of executor threads per member for the executor.
setPoolSize(int) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the number of executor threads per member for the executor.
setPoolSize(int) - Method in class com.hazelcast.internal.config.DurableExecutorConfigReadOnly
 
setPoolSize(int) - Method in class com.hazelcast.internal.config.ExecutorConfigReadOnly
 
setPoolSize(int) - Method in class com.hazelcast.internal.config.ScheduledExecutorConfigReadOnly
 
setPopulate(boolean) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
setPopulate(boolean) - Method in class com.hazelcast.config.QueryCacheConfig
Set true to enable initial population, otherwise set false.
setPopulate(boolean) - Method in class com.hazelcast.internal.config.QueryCacheConfigReadOnly
 
setPort(int) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setPort(int) - Method in class com.hazelcast.config.NetworkConfig
Sets the port the Hazelcast member will try to bind on.
setPort(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setPort(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
Sets the port the Hazelcast member will try to bind on.
setPortableFactories(Map<Integer, PortableFactory>) - Method in class com.hazelcast.config.SerializationConfig
 
setPortableFactoryClasses(Map<Integer, String>) - Method in class com.hazelcast.config.SerializationConfig
 
setPortableVersion(int) - Method in class com.hazelcast.config.SerializationConfig
 
setPortableVersion(int) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
setPortableVersion(int) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
setPortAutoIncrement(boolean) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setPortAutoIncrement(boolean) - Method in class com.hazelcast.config.NetworkConfig
Sets if a Hazelcast member is allowed to find a free port by incrementing the port number when it encounters an occupied port.
setPortAutoIncrement(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setPortAutoIncrement(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
Sets if a Hazelcast member is allowed to find a free port by incrementing the port number when it encounters an occupied port.
setPortCount(int) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setPortCount(int) - Method in class com.hazelcast.config.NetworkConfig
The maximum number of ports allowed to use.
setPortCount(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
The maximum number of ports allowed to use.
setPredicateConfig(PredicateConfig) - Method in class com.hazelcast.config.QueryCacheConfig
Sets the predicate of QueryCache.
setPredicateConfig(PredicateConfig) - Method in class com.hazelcast.internal.config.QueryCacheConfigReadOnly
 
setPredicateConfigHolder(PredicateConfigHolder) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.QueryCacheConfigHolder
 
setPredicateImpl(QueryCacheConfig) - Method in class com.hazelcast.map.impl.querycache.subscriber.AbstractQueryCacheConfigurator
 
setPredicates(Predicate<K, V>[]) - Method in class com.hazelcast.query.impl.predicates.AndPredicate
Visitable predicates are treated as effectively immutable, therefore callers should not make any changes to the array passed as argument after is has been set.
setPredicates(Predicate<K, V>[]) - Method in interface com.hazelcast.query.impl.predicates.CompoundPredicate
Set the sub-predicates of this CompoundPredicate.
setPredicates(Predicate<K, V>[]) - Method in class com.hazelcast.query.impl.predicates.OrPredicate
Visitable predicates are treated as effectively immutable, therefore callers should not make any changes to the array passed as argument after is has been set.
setPrefetchCount(int) - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
Sets how many IDs are pre-fetched on the background when one call to FlakeIdGenerator.newId() is made.
setPrefetchCount(int) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets how many IDs are pre-fetched on the background when one call to FlakeIdGenerator.newId() is made.
setPrefetchCount(int) - Method in class com.hazelcast.internal.config.FlakeIdGeneratorConfigReadOnly
 
setPrefetchValidityMillis(long) - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
Sets for how long the pre-fetched IDs can be used.
setPrefetchValidityMillis(long) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Sets for how long the pre-fetched IDs can be used.
setPrefetchValidityMillis(long) - Method in class com.hazelcast.internal.config.FlakeIdGeneratorConfigReadOnly
 
setPrefix(String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
setPrefixes(Collection<String>) - Method in class com.hazelcast.config.ClassFilter
 
setPreloaderConfig(NearCachePreloaderConfig) - Method in class com.hazelcast.config.NearCacheConfig
Sets the NearCachePreloaderConfig of this Near Cache.
setPreloaderConfig(NearCachePreloaderConfig) - Method in class com.hazelcast.internal.config.NearCacheConfigReadOnly
 
setPreMigrationLoadedStatus(boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
setPreMigrationLoadedStatus(boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Informs this recordStore about the loading status of the recordStore that this store is migrated from.
setPrincipal(String) - Method in class com.hazelcast.config.PermissionConfig
 
setPriorityPacketsRead(Counter) - Method in class com.hazelcast.internal.networking.nio.InboundHandlerWithCounters
 
setProperties(Properties) - Method in class com.hazelcast.client.config.ClientConfig
sets all properties
setProperties(Properties) - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
setProperties(Properties) - Method in class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
 
setProperties(Properties) - Method in class com.hazelcast.client.config.YamlClientConfigBuilder
 
setProperties(Properties) - Method in class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
 
setProperties(Properties) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setProperties(Map<String, String>) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
Sets the WAN publisher properties.
setProperties(Properties) - Method in class com.hazelcast.config.Config
Sets the properties for this config instance.
setProperties(Properties) - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.CustomWanPublisherConfig
 
setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.LoginModuleConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.MapStoreConfig
Sets the properties
setProperties(Properties) - Method in class com.hazelcast.config.MCMutualAuthConfig
Sets the properties.
setProperties(Properties) - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.PermissionPolicyConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.QueueStoreConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.ServiceConfig
 
setProperties(Properties) - Method in class com.hazelcast.config.SocketInterceptorConfig
Sets the properties.
setProperties(Properties) - Method in class com.hazelcast.config.SSLConfig
Sets the properties.
setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
setProperties(Map<String, Comparable>) - Method in class com.hazelcast.config.WanConsumerConfig
Sets the properties for the custom WAN consumer.
setProperties(Properties) - Method in class com.hazelcast.config.XmlConfigBuilder
Sets the used properties.
setProperties(Properties) - Method in class com.hazelcast.config.YamlConfigBuilder
 
setProperties(Properties) - Method in class com.hazelcast.internal.config.MapStoreConfigReadOnly
 
setProperties(Properties) - Method in class com.hazelcast.internal.config.QueueStoreConfigReadOnly
 
setProperties(Properties) - Method in class com.hazelcast.internal.config.RingbufferStoreConfigReadOnly
 
setProperties(Properties) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setPropertiesInternal(Properties) - Method in class com.hazelcast.config.AbstractXmlConfigBuilder
Sets the used properties.
setPropertiesInternal(Properties) - Method in class com.hazelcast.config.AbstractYamlConfigBuilder
 
setProperty(String, String) - Method in class com.hazelcast.client.config.ClientConfig
Sets the value of a named property.
setProperty(String, String) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setProperty(String, String) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Sets the property understood by the given SPI Discovery Strategy.
setProperty(String, String) - Method in class com.hazelcast.config.Config
Sets the value of a named property.
setProperty(String, String) - Method in class com.hazelcast.config.MapStoreConfig
 
setProperty(String, String) - Method in class com.hazelcast.config.MCMutualAuthConfig
Sets a property.
setProperty(String, String) - Method in class com.hazelcast.config.QueueStoreConfig
 
setProperty(String, String) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setProperty(String, String) - Method in class com.hazelcast.config.SocketInterceptorConfig
Sets a property.
setProperty(String, String) - Method in class com.hazelcast.config.SSLConfig
Sets a property.
setProperty(String, String) - Method in class com.hazelcast.internal.config.MapStoreConfigReadOnly
 
setProperty(String, String) - Method in class com.hazelcast.internal.config.QueueStoreConfigReadOnly
 
setProperty(String, String) - Method in class com.hazelcast.internal.config.RingbufferStoreConfigReadOnly
 
setProperty(String, String) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setProtectOn(SplitBrainProtectionOn) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
setProviderFilter(String) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Filter to limit members that can be used for classloading request when a user class is not available locally.
setProviderMode(UserCodeDeploymentConfig.ProviderMode) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Configure behaviour when providing classes to remote members.
setProxyFactoryConfigs(List<ProxyFactoryConfig>) - Method in class com.hazelcast.client.config.ClientConfig
SetProxyImpl<E> - Class in com.hazelcast.collection.impl.set
 
SetProxyImpl(String, NodeEngine, SetService) - Constructor for class com.hazelcast.collection.impl.set.SetProxyImpl
 
setProxyServiceBean(ProxyServiceDTO) - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
 
setPublicAddress(String) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setPublicAddress(String) - Method in class com.hazelcast.config.NetworkConfig
Overrides the public address of a member.
setPublicAddress(String) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setPublicAddress(String) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
Overrides the public address of a member.
setPublishable(boolean) - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
 
setPublisherId(String) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
Sets the publisher ID used for identifying the publisher in a WanReplicationConfig.
setPublisherId(String) - Method in class com.hazelcast.config.CustomWanPublisherConfig
 
setPublisherId(String) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
setPublisherListenerId(UUID) - Method in interface com.hazelcast.map.impl.querycache.subscriber.InternalQueryCache
 
setPublisherListenerId(UUID) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
setQueryCacheConfigs(Map<String, Map<String, QueryCacheConfig>>) - Method in class com.hazelcast.client.config.ClientConfig
 
setQueryCacheConfigs(List<QueryCacheConfig>) - Method in class com.hazelcast.config.MapConfig
Sets QueryCacheConfig instances to this MapConfig.
setQueryCacheConfigs(List<QueryCacheConfig>) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setQueryCount(long) - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
Sets the query count of this stats to the given query count.
setQueryCount(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
Sets the query count of this stats to the given query count value.
setQueryCount(long) - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Sets the query count to the given value.
setQueueCapacity(int) - Method in class com.hazelcast.config.ExecutorConfig
Sets the queue capacity of the executor task.
setQueueCapacity(int) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the capacity of the primary and backup queue for WAN replication events.
setQueueCapacity(int) - Method in class com.hazelcast.internal.config.ExecutorConfigReadOnly
 
setQueueConfigs(Map<String, QueueConfig>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setQueueConfigs(Map<String, QueueConfig>) - Method in class com.hazelcast.config.Config
Sets the map of IQueue configurations, mapped by config name.
setQueueConfigs(Map<String, QueueConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setQueueFullBehavior(WanQueueFullBehavior) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the configured behaviour of this WAN publisher when the WAN queue is full.
setQueueStoreConfig(QueueStoreConfig) - Method in class com.hazelcast.config.QueueConfig
Set the QueueStore (load and store queue items from/to a database) configuration.
setQueueStoreConfig(QueueStoreConfig) - Method in class com.hazelcast.internal.config.QueueConfigReadOnly
 
setRaftAlgorithmConfig(RaftAlgorithmConfig) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets configuration options for Hazelcast's Raft consensus algorithm implementation
setRaftNode(RaftNode) - Method in interface com.hazelcast.cp.internal.RaftNodeAware
 
setRaftNode(RaftNode) - Method in class com.hazelcast.cp.internal.raftop.GetInitialRaftGroupMembersIfCurrentGroupMemberOp
 
setReadBackupData(boolean) - Method in class com.hazelcast.config.MapConfig
Sets read-backup-data (reading local backup entries) for this map.
setReadBackupData(boolean) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setReadBatchSize(int) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Sets the read batch size.
setReadBatchSize(int) - Method in class com.hazelcast.config.ReliableTopicConfig
Sets the read batch size.
setReadBatchSize(int) - Method in class com.hazelcast.internal.config.ReliableTopicConfigReadOnly
 
SetReadCursorOperation - Class in com.hazelcast.map.impl.querycache.subscriber.operation
Sets read cursor of Accumulator in this partition to the supplied sequence number.
SetReadCursorOperation() - Constructor for class com.hazelcast.map.impl.querycache.subscriber.operation.SetReadCursorOperation
 
SetReadCursorOperation(String, String, long, int) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.operation.SetReadCursorOperation
 
setReadThrough(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setReadThrough(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
Set if read-through caching should be used.
setReadThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
Enables or disables read-through: a read loads the entry from the data store if it is not already in the cache.
setReadThrough(boolean) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setReadThrough(boolean) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setReadTimeout(long) - Method in class com.hazelcast.spring.cache.HazelcastCache
Set cache value retrieval timeout
setRealmConfigs(Map<String, RealmConfig>) - Method in class com.hazelcast.config.SecurityConfig
 
setRealmConfigs(Map<String, RealmConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
setReconnectMode(ClientConnectionStrategyConfig.ReconnectMode) - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
How a client reconnect to cluster after a disconnect can be configured.
setRecord(Record) - Method in class com.hazelcast.query.impl.QueryableEntry
 
setRecordId(long) - Method in class com.hazelcast.multimap.impl.MultiMapRecord
 
setRedoOperation(boolean) - Method in class com.hazelcast.client.config.ClientNetworkConfig
If true, client will redo the operations that were executing on the server and client lost the connection.
setReferenceCallId(long) - Method in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
setRegion(String) - Method in class com.hazelcast.config.AwsConfig
setReliableTopicConfigMap(Map<String, ClientReliableTopicConfig>) - Method in class com.hazelcast.client.config.ClientConfig
Sets the map of ClientReliableTopicConfig, mapped by config name.
setReliableTopicConfigs(Map<String, ReliableTopicConfig>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setReliableTopicConfigs(Map<String, ReliableTopicConfig>) - Method in class com.hazelcast.config.Config
Sets the map of reliable topic configurations, mapped by config name.
setReliableTopicConfigs(Map<String, ReliableTopicConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setRemoteEndpoint(Address) - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
SetRemoveCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the specified element from this set if it is present (optional operation).
SetRemoveCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetRemoveCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
setRemoveCount(long) - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
Sets the remove count of this stats to the given remove count.
setRemoveCount(long) - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Sets the remove count to the given value.
SetRemoveListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the specified item listener.
SetRemoveListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetRemoveListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetRemoveListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
SetRemoveListenerMessageTask
SetRemoveListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetRemoveListenerMessageTask
 
SetRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
SetRemoveMessageTask
SetRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetRemoveMessageTask
 
setRemoveOperation(boolean) - Method in class com.hazelcast.collection.impl.collection.TxCollectionItem
 
setReplicaCount(int) - Method in class com.hazelcast.config.PNCounterConfig
Sets the number of replicas on which state for this PN counter will be kept.
setReplicaCount(int) - Method in class com.hazelcast.internal.config.PNCounterConfigReadOnly
 
setReplicaIndex(int) - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Sets the replicaIndex.
setReplicaIndex(int) - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
setReplicatedMapConfigs(Map<String, ReplicatedMapConfig>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setReplicatedMapConfigs(Map<String, ReplicatedMapConfig>) - Method in class com.hazelcast.config.Config
Sets the map of ReplicatedMap configurations, mapped by config name.
setReplicatedMapConfigs(Map<String, ReplicatedMapConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setReplicaTimestamp(UUID, long) - Method in class com.hazelcast.cluster.impl.VectorClock
Sets the logical timestamp for the given replicaId.
SetReplicationOperation - Class in com.hazelcast.collection.impl.set.operations
 
SetReplicationOperation() - Constructor for class com.hazelcast.collection.impl.set.operations.SetReplicationOperation
 
SetReplicationOperation(Map<String, CollectionContainer>, int, int) - Constructor for class com.hazelcast.collection.impl.set.operations.SetReplicationOperation
 
setReplicationPeriodMillis(int) - Method in class com.hazelcast.config.CRDTReplicationConfig
Sets the period between two replications of CRDT states in milliseconds.
setRepublishingEnabled(boolean) - Method in class com.hazelcast.config.WanReplicationRef
Sets if incoming WAN events to this member should be republished (forwarded) to this WAN replication reference.
setRepublishingEnabled(boolean) - Method in class com.hazelcast.internal.config.WanReplicationRefReadOnly
 
setRequiredMember(String) - Method in class com.hazelcast.config.TcpIpConfig
Sets the required member.
setResponse(byte[]) - Method in class com.hazelcast.internal.ascii.memcache.DeleteCommand
 
setResponse(byte[]) - Method in class com.hazelcast.internal.ascii.memcache.IncrementCommand
 
setResponse(byte[]) - Method in class com.hazelcast.internal.ascii.memcache.SetCommand
 
setResponse(byte[]) - Method in class com.hazelcast.internal.ascii.memcache.SimpleCommand
 
setResponse(Stats) - Method in class com.hazelcast.internal.ascii.memcache.StatsCommand
 
setResponse(byte[]) - Method in class com.hazelcast.internal.ascii.memcache.TouchCommand
 
setResponse(byte[]) - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
 
setResponse(Map<String, Object>) - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
HTTP/1.0 200 OK Content-Length: 0 Custom-Header1: val1 Custom-Header2: val2
setResponse(byte[], byte[]) - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
HTTP/1.0 200 OK Date: Fri, 31 Dec 1999 23:59:59 GMT Content-TextCommandType: text/html Content-Length: 1354
setResponseTimeoutMillis(int) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the duration in milliseconds for the waiting time before retrying to send the events to target cluster again in case of acknowledgement is not arrived.
setRestApiConfig(RestApiConfig) - Method in class com.hazelcast.config.NetworkConfig
 
setRestEndpointConfig(RestServerEndpointConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig
Sets the server socket endpoint config for REST protocol.
setResult(Collection<MemcacheEntry>) - Method in class com.hazelcast.internal.ascii.memcache.BulkGetCommand
 
setResult(Result) - Method in class com.hazelcast.map.impl.query.ResultSegment
 
setResultDeserialized(boolean) - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Sets the automatic deserialized option for the result.
setRetentionSeconds(int) - Method in class com.hazelcast.config.MetricsConfig
Sets the number of seconds the metrics will be retained on the instance.
setRetryable(boolean) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
setReuseAddress(boolean) - Method in class com.hazelcast.client.config.SocketOptions
Enable/disable the SO_REUSEADDR socket option.
setReuseAddress(boolean) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setReuseAddress(boolean) - Method in class com.hazelcast.config.NetworkConfig
Sets the reuse address.
setReuseAddress(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setReuseAddress(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
Sets the reuse address.
setRingbufferConfigs(Map<String, RingbufferConfig>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setRingbufferConfigs(Map<String, RingbufferConfig>) - Method in class com.hazelcast.config.Config
Sets the map of Ringbuffer configurations, mapped by config name.
setRingbufferConfigs(Map<String, RingbufferConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setRingbufferStoreConfig(RingbufferStoreConfig) - Method in class com.hazelcast.config.RingbufferConfig
Set the RingbufferStore (load and store ringbuffer items from/to a database) configuration.
setRingbufferStoreConfig(RingbufferStoreConfig) - Method in class com.hazelcast.internal.config.RingbufferConfigReadOnly
 
setRoleAttribute(String) - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
 
setRoleContext(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setRoleFilter(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setRoleMappingAttribute(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setRoleMappingMode(LdapRoleMappingMode) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setRoleNameAttribute(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setRoleRecursionMaxDepth(int) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setRoleSearchScope(LdapSearchScope) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setRunnable(Runnable) - Method in class com.hazelcast.executor.impl.RunnableAdapter
 
setRunnable(Runnable) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledRunnableAdapter
 
setRunningCleanupOperation(boolean) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
 
setRuntimeProps(Map<String, Long>) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
setSalt(String) - Method in class com.hazelcast.config.AbstractSymmetricEncryptionConfig
Sets the salt used for encryption.
setScheduledExecutorConfigs(Map<String, ScheduledExecutorConfig>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setScheduledExecutorConfigs(Map<String, ScheduledExecutorConfig>) - Method in class com.hazelcast.config.Config
Sets the map of scheduled executor configurations, mapped by config name.
setScheduledExecutorConfigs(Map<String, ScheduledExecutorConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setScopeId(String) - Method in class com.hazelcast.cluster.Address
 
setScriptEngineManager(ScriptEngineManager) - Static method in class com.hazelcast.internal.management.ScriptEngineManagerContext
 
setScriptingEnabled(boolean) - Method in class com.hazelcast.config.ManagementCenterConfig
Enables/disables scripting on the member.
setScriptingEnabled(boolean) - Method in class com.hazelcast.internal.management.TimedMemberState
 
setSecretKey(String) - Method in class com.hazelcast.config.AwsConfig
setSecretPath(String) - Method in class com.hazelcast.config.VaultSecureStoreConfig
Sets the Vault secret path where the encryption keys is expected to be stored.
setSecureStoreConfig(SecureStoreConfig) - Method in class com.hazelcast.config.EncryptionAtRestConfig
Sets the Secure Store configuration.
setSecurityConfig(ClientSecurityConfig) - Method in class com.hazelcast.client.config.ClientConfig
setSecurityConfig(SecurityConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setSecurityConfig(SecurityConfig) - Method in class com.hazelcast.config.Config
Sets the security configuration for this hazelcast instance.
setSecurityConfig(SecurityConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setSecurityGroupName(String) - Method in class com.hazelcast.config.AwsConfig
setSecurityInterceptorConfigs(List<SecurityInterceptorConfig>) - Method in class com.hazelcast.config.SecurityConfig
 
setSecurityInterceptorConfigs(List<SecurityInterceptorConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
setSelectionKeyWakeupEnabled(boolean) - Method in class com.hazelcast.internal.networking.nio.NioNetworking.Context
 
setSemaphoreConfigs(Map<String, SemaphoreConfig>) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the map of CP ISemaphore configurations, mapped by config name.
setSendConnection(ClientConnection) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocation
 
setSentCacheEventCounter(Map<String, DistributedServiceWanEventCounters.DistributedObjectWanEventCounters>) - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
setSentMapEventCounter(Map<String, DistributedServiceWanEventCounters.DistributedObjectWanEventCounters>) - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
setSequence(long) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataContainer
 
setSequence(long) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntry
 
setSequence(long) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
setSequence(long) - Method in class com.hazelcast.map.impl.querycache.event.BatchEventData
 
setSequence(long) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
setSequence(long) - Method in class com.hazelcast.map.impl.querycache.event.sequence.DefaultPartitionSequencer
 
setSequence(long) - Method in interface com.hazelcast.map.impl.querycache.event.sequence.PartitionSequencer
Sets the current sequence number for the partition.
setSequence(long) - Method in interface com.hazelcast.map.impl.querycache.event.sequence.Sequenced
Sets sequence.
setSequence(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
setSequence(long) - Method in interface com.hazelcast.map.impl.record.Record
Only used for Hot Restart, HDRecord
setSerializationConfig(SerializationConfig) - Method in class com.hazelcast.client.config.ClientConfig
setSerializationConfig(SerializationConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setSerializationConfig(SerializationConfig) - Method in class com.hazelcast.config.Config
Sets the serialization configuration for this hazelcast instance.
setSerializationConfig(SerializationConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setSerializationService(SerializationService) - Method in interface com.hazelcast.internal.serialization.SerializationServiceAware
Gets the SerializationService reference injected.
setSerializationService(SerializationService) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
setSerializationService(SerializationService) - Method in interface com.hazelcast.map.impl.querycache.event.QueryCacheEventData
 
setSerializationService(SerializationService) - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
 
setSerializationService(SerializationService) - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
 
setSerializationService(SerializationService) - Method in class com.hazelcast.spi.impl.merge.AbstractCollectionMergingValueImpl
 
setSerializationService(SerializationService) - Method in class com.hazelcast.spi.impl.merge.AbstractMergingEntryImpl
 
setSerializationService(SerializationService) - Method in class com.hazelcast.spi.impl.merge.AbstractMergingValueImpl
 
setSerializationService(SerializationService) - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
setSerializationService(SerializationService) - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
setSerializationService(SerializationService) - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
setSerializationService(SerializationService) - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
setSerializationService(SerializationService) - Method in class com.hazelcast.spi.impl.merge.RingbufferMergingValueImpl
 
setSerializeKeys(boolean) - Method in class com.hazelcast.config.NearCacheConfig
Sets if the Near Cache key is stored in serialized format or by-reference.
setSerializeKeys(boolean) - Method in class com.hazelcast.internal.config.NearCacheConfigReadOnly
 
setSerializerConfigs(Collection<SerializerConfig>) - Method in class com.hazelcast.config.SerializationConfig
 
setServerHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.instance.impl.OutOfMemoryErrorDispatcher
 
setService(String) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
SetService - Class in com.hazelcast.collection.impl.set
 
SetService(NodeEngine) - Constructor for class com.hazelcast.collection.impl.set.SetService
 
setService(MapService) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
setService(Object) - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
setServiceConfigs(Collection<ServiceConfig>) - Method in class com.hazelcast.config.ServicesConfig
 
setServiceImpl(Object) - Method in class com.hazelcast.config.ServiceConfig
setServiceName(String) - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
setServicesConfig(ServicesConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setServicesConfig(ServicesConfig) - Method in class com.hazelcast.config.Config
Sets the configuration for the user services managed by this hazelcast instance.
setServicesConfig(ServicesConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setSessionAccessor(SessionAccessor) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
setSessionAccessor(SessionAccessor) - Method in interface com.hazelcast.cp.internal.session.SessionAwareService
Injects SessionAccessor in order to enable the custom service to validate and trigger session activity
setSessionHeartbeatIntervalSeconds(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the interval for the periodically-committed CP session heartbeats.
setSessionTimeToLiveSeconds(int) - Method in class com.hazelcast.config.cp.CPSubsystemConfig
Sets the duration for a CP session to be kept alive after its last session heartbeat.
setSetConfigs(Map<String, SetConfig>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setSetConfigs(Map<String, SetConfig>) - Method in class com.hazelcast.config.Config
Sets the map of ISet configurations, mapped by config name.
setSetConfigs(Map<String, SetConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setShuttingDown() - Method in class com.hazelcast.instance.impl.Node
 
setSize(int) - Method in class com.hazelcast.config.EvictionConfig
Sets the size which is used by the EvictionConfig.MaxSizePolicy.
setSize(int) - Method in class com.hazelcast.config.MaxSizeConfig
Sets the maximum size of the map.
setSize(MemorySize) - Method in class com.hazelcast.config.NativeMemoryConfig
Sets size of the native memory region.
setSize(int) - Method in class com.hazelcast.internal.config.EvictionConfigReadOnly
 
setSize(int) - Method in class com.hazelcast.internal.config.MaxSizeConfigReadOnly
 
SetSizeCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the number of elements in this set (its cardinality).
SetSizeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetSizeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
SetSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
SetSizeMessageTask
SetSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetSizeMessageTask
 
setSmartRouting(boolean) - Method in class com.hazelcast.client.config.ClientNetworkConfig
If true, client will route the key based operations to owner of the key on best-effort basis.
setSnapshot(SnapshotEntry) - Method in class com.hazelcast.cp.internal.raft.impl.log.RaftLog
Installs the snapshot entry and truncates log entries those are included in the snapshot (entries whose indexes are smaller than or equal to the snapshot's index).
setSnapshot(SnapshotEntry, long) - Method in class com.hazelcast.cp.internal.raft.impl.log.RaftLog
 
setSnapshotEnabled(boolean) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets if key-based coalescing is configured for this WAN publisher.
setSocketBufferDirect(boolean) - Method in class com.hazelcast.config.EndpointConfig
 
setSocketBufferDirect(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSocketBufferDirect(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSocketConnectTimeoutSeconds(int) - Method in class com.hazelcast.config.EndpointConfig
 
setSocketConnectTimeoutSeconds(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSocketConnectTimeoutSeconds(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSocketFactoryClassName(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.EndpointConfig
setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.NetworkConfig
setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSocketInterceptorEnabled(boolean) - Method in class com.hazelcast.internal.management.TimedMemberState
 
setSocketKeepAlive(boolean) - Method in class com.hazelcast.config.EndpointConfig
 
setSocketKeepAlive(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSocketKeepAlive(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSocketLingerSeconds(int) - Method in class com.hazelcast.config.EndpointConfig
 
setSocketLingerSeconds(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSocketLingerSeconds(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSocketOptions(SocketOptions) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
setSocketRcvBufferSizeKb(int) - Method in class com.hazelcast.config.EndpointConfig
 
setSocketRcvBufferSizeKb(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSocketRcvBufferSizeKb(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSocketSendBufferSizeKb(int) - Method in class com.hazelcast.config.EndpointConfig
 
setSocketSendBufferSizeKb(int) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSocketSendBufferSizeKb(int) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSocketTcpNoDelay(boolean) - Method in class com.hazelcast.config.EndpointConfig
 
setSocketTcpNoDelay(boolean) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSocketTcpNoDelay(boolean) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSplitBrainProtectionConfigs(Map<String, SplitBrainProtectionConfig>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setSplitBrainProtectionConfigs(Map<String, SplitBrainProtectionConfig>) - Method in class com.hazelcast.config.Config
Sets the map of split-brain protection configurations, mapped by config name.
setSplitBrainProtectionConfigs(Map<String, SplitBrainProtectionConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.AbstractBasicConfig
Sets the split brain protection name for operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.CacheConfig
Associates this cache configuration to a split brain protection.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Associates this cache configuration to a split brain protection.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
Sets the split brain protection name for operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.CollectionConfig
Sets the split brain protection name for operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.DurableExecutorConfig
Sets the split brain protection name for operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.ExecutorConfig
Sets the split brain protection name for operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.MapConfig
 
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.MultiMapConfig
Sets the split brain protection name for operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.PNCounterConfig
Sets the split brain protection name for operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.QueueConfig
Sets the split brain protection name for queue operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.ReplicatedMapConfig
Sets the split brain protection name for operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.RingbufferConfig
Sets the split brain protection name for operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.config.ScheduledExecutorConfig
Sets the split brain protection name for operations.
setSplitBrainProtectionName(String) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setSplitBrainProtectionName(String) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setSplitBrainProtectionName(String) - Method in class com.hazelcast.internal.config.CardinalityEstimatorConfigReadOnly
 
setSplitBrainProtectionName(String) - Method in class com.hazelcast.internal.config.DurableExecutorConfigReadOnly
 
setSplitBrainProtectionName(String) - Method in class com.hazelcast.internal.config.ExecutorConfigReadOnly
 
setSplitBrainProtectionName(String) - Method in class com.hazelcast.internal.config.ListConfigReadOnly
 
setSplitBrainProtectionName(String) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setSplitBrainProtectionName(String) - Method in class com.hazelcast.internal.config.MultiMapConfigReadOnly
 
setSplitBrainProtectionName(String) - Method in class com.hazelcast.internal.config.PNCounterConfigReadOnly
 
setSplitBrainProtectionName(String) - Method in class com.hazelcast.internal.config.QueueConfigReadOnly
 
setSplitBrainProtectionName(String) - Method in class com.hazelcast.internal.config.ReplicatedMapConfigReadOnly
 
setSplitBrainProtectionName(String) - Method in class com.hazelcast.internal.config.RingbufferConfigReadOnly
 
setSplitBrainProtectionName(String) - Method in class com.hazelcast.internal.config.ScheduledExecutorConfigReadOnly
 
setSplitBrainProtectionName(String) - Method in class com.hazelcast.internal.config.SetConfigReadOnly
 
setSql(String) - Method in class com.hazelcast.config.PredicateConfig
Sets sql string for this config.
setSql(String) - Method in class com.hazelcast.internal.config.PredicateConfigReadOnly
 
setSSLConfig(SSLConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets the SSLConfig.
setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.EndpointConfig
Sets the SSLConfig.
setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.NetworkConfig
Sets the SSLConfig.
setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.VaultSecureStoreConfig
Sets the SSL/TLS configuration.
setSslEnabled(boolean) - Method in class com.hazelcast.internal.management.TimedMemberState
 
setStaleReadDetector(StaleReadDetector) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
setStaleReadDetector(StaleReadDetector) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
 
setState(WanPublisherState) - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
setStatisticsEnabled(CacheConfig, String, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
setStatisticsEnabled(CacheConfig, String, boolean) - Method in interface com.hazelcast.cache.impl.ICacheService
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
Sets whether or not statistics gathering is enabled on this cache.
setStatisticsEnabled(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
Sets whether statistics gathering is enabled on a cache.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets statistics to enabled or disabled for this ICache.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CollectionConfig
Sets collection statistics to enabled or disabled.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ExecutorConfig
Enables or disables statistics gathering on the executor task.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
Enables or disables statistics gathering of LocalFlakeIdGeneratorStats.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MapConfig
Sets statistics to enabled or disabled for this map.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MultiMapConfig
Enables or disables statistics for this MultiMap.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.PNCounterConfig
Enables or disables statistics for this PN counter
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.QueueConfig
Enables or disables statistics for this queue.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ReliableTopicConfig
Enables or disables statistics for this reliable topic.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ReplicatedMapConfig
Sets statistics to enabled or disabled for this replicated map.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
Enables or disables statistics for this topic.
setStatisticsEnabled(boolean) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.internal.config.ExecutorConfigReadOnly
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.internal.config.FlakeIdGeneratorConfigReadOnly
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.internal.config.ListConfigReadOnly
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.internal.config.MultiMapConfigReadOnly
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.internal.config.PNCounterConfigReadOnly
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.internal.config.QueueConfigReadOnly
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.internal.config.ReliableTopicConfigReadOnly
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.internal.config.ReplicatedMapConfigReadOnly
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.internal.config.SetConfigReadOnly
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.internal.config.TopicConfigReadOnly
 
setStats(LocalQueueStatsImpl) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
 
setStatus(RaftNodeStatus) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
setStatus(MigrationInfo.MigrationStatus) - Method in class com.hazelcast.internal.partition.MigrationInfo
 
setStoreAdapter(StoreAdapter) - Method in class com.hazelcast.query.impl.QueryableEntry
 
setStoreByValue(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
Set if a configured cache should use store-by-value or store-by-reference semantics.
setStoreByValue(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
Set if a configured cache should use store-by-value or store-by-reference semantics.
setStoreByValue(boolean) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setStoreImplementation(QueueStore) - Method in class com.hazelcast.config.QueueStoreConfig
 
setStoreImplementation(RingbufferStore) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
setStoreImplementation(QueueStore) - Method in class com.hazelcast.internal.config.QueueStoreConfigReadOnly
 
setStoreImplementation(RingbufferStore) - Method in class com.hazelcast.internal.config.RingbufferStoreConfigReadOnly
 
setStoreInitialDelaySeconds(int) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
setStoreInitialDelaySeconds(int) - Method in class com.hazelcast.internal.config.NearCachePreloaderConfigReadOnly
 
setStoreIntervalSeconds(int) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
setStoreIntervalSeconds(int) - Method in class com.hazelcast.internal.config.NearCachePreloaderConfigReadOnly
 
setStoreTime(long) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntry
 
setSubscriberContext(SubscriberContext) - Method in class com.hazelcast.client.impl.querycache.ClientQueryCacheContext
 
setSubscriberContext(SubscriberContext) - Method in class com.hazelcast.map.impl.querycache.NodeQueryCacheContext
 
setSubscriberContext(SubscriberContext) - Method in interface com.hazelcast.map.impl.querycache.QueryCacheContext
Only used for testing purposes.
setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.EndpointConfig
setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.NetworkConfig
setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.RestServerEndpointConfig
 
setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
setSyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
Deprecated.
setSyncBackupCount(int) - Method in class com.hazelcast.internal.config.MultiMapConfigReadOnly
 
setSynchronous(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
If true, this cache entry listener implementation will be called in a synchronous manner.
setSynchronous(boolean) - Method in class com.hazelcast.internal.config.CacheSimpleEntryListenerConfigReadOnly
 
setSystemProperty(String) - Method in class com.hazelcast.spi.properties.HazelcastProperty
Sets the system property value of the property.
setSystemUserDn(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setSystemUserPassword(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setTagKey(String) - Method in class com.hazelcast.config.AwsConfig
setTagValue(String) - Method in class com.hazelcast.config.AwsConfig
setTailSequence(long) - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
 
setTailSequence(long) - Method in interface com.hazelcast.ringbuffer.impl.Ringbuffer
Sets the tail sequence.
setTailSequence(long) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
Sets the tail sequence.
setTailSequence(long) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Sets the tail sequence.
setTarget(Address) - Method in class com.hazelcast.internal.cluster.impl.operations.FinalizeJoinOp
 
setTarget(Address) - Method in class com.hazelcast.internal.cluster.impl.operations.OnJoinOp
 
setTarget(Address) - Method in class com.hazelcast.internal.partition.operation.MigrationOperation
 
setTarget(Address) - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncResponse
 
setTarget(Address) - Method in class com.hazelcast.internal.partition.ReplicaFragmentMigrationState
 
setTarget(Address) - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
 
setTarget(Address) - Method in interface com.hazelcast.spi.impl.operationservice.TargetAware
Provides the designated target member address to which the operation will be sent.
setTargetAddress(Address) - Method in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
setTargetAddress(Address) - Method in interface com.hazelcast.internal.cluster.Joiner
 
setTargetEndpoint(RaftEndpoint) - Method in class com.hazelcast.cp.internal.operation.integration.AsyncRaftOp
 
setTargetEndpoints(String) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the comma separated list of target cluster members, e.g.
setTcpIpConfig(TcpIpConfig) - Method in class com.hazelcast.config.JoinConfig
 
setTcpNoDelay(boolean) - Method in class com.hazelcast.client.config.SocketOptions
Enable/disable TCP_NODELAY socket option.
setTenant(boolean) - Method in class com.hazelcast.spi.impl.tenantcontrol.NoopTenantControl
 
setTenant(boolean) - Method in interface com.hazelcast.spi.tenantcontrol.TenantControl
Establish this tenant's thread-local context Particular TenantControl implementation will control the details of how createRequestScope parameter is handled, but in general, if createRequestScope = false, only ClassLoader is set up, if createRequestScope = true, in addition to ClassLoader, other things like invocation, EJB/JPA/CDI context should be set up as well In other words, if only app class needs to be resolved, set createRequestScope to false If actually calling into user's code, set createRequestScope to true
setTenantControl(CacheConfig) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
setTenantControl(CacheConfig<K, V>) - Method in interface com.hazelcast.cache.impl.ICacheService
 
setTenantControl(CacheConfig<K, V>, TenantControl) - Static method in class com.hazelcast.config.CacheConfigAccessor
 
setTextContent(String) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
setThisMember(MemberImpl) - Method in class com.hazelcast.logging.impl.LoggingServiceImpl
 
setThisMemberAsMaster() - Method in class com.hazelcast.internal.cluster.impl.ClusterJoinManager
 
setThreadId(long) - Static method in class com.hazelcast.internal.util.ThreadUtil
Set the thread ID.
setThreadId(long) - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
 
setThreadId(long) - Method in class com.hazelcast.map.impl.operation.MapOperation
 
setThreadId(long) - Method in class com.hazelcast.map.impl.operation.ReadonlyKeyBasedMapOperation
 
setThreadId(long) - Method in interface com.hazelcast.map.impl.tx.MapTxnOperation
 
setThreadId(long) - Method in class com.hazelcast.multimap.impl.operations.AbstractKeyBasedMultiMapOperation
 
setThreadId(long) - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
 
setThreads(int) - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
setTime(long) - Method in class com.hazelcast.internal.management.TimedMemberState
 
setTimeout(long, TimeUnit) - Method in class com.hazelcast.transaction.TransactionOptions
Sets the timeout.
setTimeoutMilliseconds(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
setTimeoutMilliseconds(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Sets the timeout in Milliseconds before declaring a failed ping This cannot be more than the interval value.
setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.EventJournalConfig
Sets the time to live in seconds.
setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.MapConfig
The maximum number of seconds for each entry to stay in the map.
setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.NearCacheConfig
Returns the maximum number of seconds for each entry to stay in the Near Cache (time to live).
setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.RingbufferConfig
Sets the time to live in seconds which is the maximum number of seconds for each item to stay in the ringbuffer before being removed.
setTimeToLiveSeconds(int) - Method in class com.hazelcast.internal.config.EventJournalConfigReadOnly
 
setTimeToLiveSeconds(int) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setTimeToLiveSeconds(int) - Method in class com.hazelcast.internal.config.NearCacheConfigReadOnly
 
setTimeToLiveSeconds(int) - Method in class com.hazelcast.internal.config.RingbufferConfigReadOnly
 
setTlsAuthenticationConfig(TlsAuthenticationConfig) - Method in class com.hazelcast.config.security.RealmConfig
 
setToken(String) - Method in class com.hazelcast.config.VaultSecureStoreConfig
Sets the Vault access token.
setTokenIdentityConfig(TokenIdentityConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
setTokenIdentityConfig(TokenIdentityConfig) - Method in class com.hazelcast.config.security.RealmConfig
 
setTopicConfigs(Map<String, TopicConfig>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setTopicConfigs(Map<String, TopicConfig>) - Method in class com.hazelcast.config.Config
Sets the map of ITopic configurations, mapped by config name.
setTopicConfigs(Map<String, TopicConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setTopicOverloadPolicy(TopicOverloadPolicy) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
Sets the TopicOverloadPolicy for this reliable topic.
setTopicOverloadPolicy(TopicOverloadPolicy) - Method in class com.hazelcast.config.ReliableTopicConfig
Sets the TopicOverloadPolicy for this reliable topic.
setTopicOverloadPolicy(TopicOverloadPolicy) - Method in class com.hazelcast.internal.config.ReliableTopicConfigReadOnly
 
setTotalConnections(int) - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
setTotalHitCount(long) - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Sets the total hit count to the given value.
setTotalInsertLatency(long) - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
Sets the total insert latency of this stats to the given total insert latency.
setTotalInsertLatency(long) - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Sets the total insert latency to the given value.
setTotalPhysical(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
setTotalRemoveLatency(long) - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
Sets the total remove latency of this stats to the given total remove latency.
setTotalRemoveLatency(long) - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Sets the total remove latency to the given value.
setTotalUpdateLatency(long) - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
Sets the total update latency of this stats to the given total update latency.
setTotalUpdateLatency(long) - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Sets the total update latency to the given value.
setTransactionContext(TransactionContext) - Method in interface com.hazelcast.client.impl.ClientEndpoint
 
setTransactionContext(TransactionContext) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
setTransactionId(UUID) - Method in class com.hazelcast.collection.impl.collection.TxCollectionItem
 
setTransactionId(UUID) - Method in class com.hazelcast.collection.impl.txnqueue.TxQueueItem
 
setTransactionId(UUID) - Method in interface com.hazelcast.map.impl.tx.MapTxnOperation
 
setTransactionId(UUID) - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
 
setTransactionId(UUID) - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
 
setTransactionId(UUID) - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
 
setTransactionTimeout(int) - Method in class com.hazelcast.client.impl.proxy.txn.xa.XAResourceProxy
 
setTransactionTimeout(int) - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
 
setTransactionType(TransactionOptions.TransactionType) - Method in class com.hazelcast.transaction.TransactionOptions
setTrustedInterfaces(Set<String>) - Method in class com.hazelcast.config.MulticastConfig
Sets the trusted interfaces.
setTryCount(int) - Method in class com.hazelcast.client.config.ClientFailoverConfig
 
setTryCount(int) - Method in class com.hazelcast.internal.cluster.impl.JoinRequest
 
setTryCount(int) - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Sets the try count; the number of times this operation can be retried.
setTryPauseMillis(long) - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Sets the pause time in milliseconds.
setTtl(int) - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
setTtl(K, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
setTtl(int) - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
Sets the maximum number of times the IP Datagram (ping) can be forwarded, in most cases all Hazelcast cluster members would be within one network switch/router therefore
setTtl(K, long, TimeUnit) - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
setTtl(K, long, TimeUnit) - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
setTtl(K, long, TimeUnit) - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
setTtl(K, long, TimeUnit) - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
setTtl(K, long, TimeUnit) - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
setTtl(K, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Updates the TTL (time to live) value of the entry specified by key with a new TTL value.
setTtl(K, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
setTtl(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
setTtl(long) - Method in interface com.hazelcast.map.impl.record.Record
 
setTtl(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
 
setTtl(Data, long) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
setTtl(Data, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
setTtl(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
setTtl(long) - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
setTtl(long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
setTtl(long) - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
setTtl(long) - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
SetTtlBackupOperation - Class in com.hazelcast.map.impl.operation
 
SetTtlBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.SetTtlBackupOperation
 
SetTtlBackupOperation(String, Data, long) - Constructor for class com.hazelcast.map.impl.operation.SetTtlBackupOperation
 
setTtlInternal(Object, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
setTtlInternal(Object, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
setTtlInternal(Object, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
SetTtlOperation - Class in com.hazelcast.map.impl.operation
 
SetTtlOperation() - Constructor for class com.hazelcast.map.impl.operation.SetTtlOperation
 
SetTtlOperation(String, Data, long) - Constructor for class com.hazelcast.map.impl.operation.SetTtlOperation
 
setTxn(Data, Object, long, long, UUID) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
setTxn(Data, Object, long, long, UUID) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
setTxnId(UUID) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntry
 
setType(ConnectionType) - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
setType(IndexType) - Method in class com.hazelcast.config.IndexConfig
Sets type of the index.
setType(String) - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
Sets the Java KeyStore type (PKCS12, JCEKS etc.)
setType(PermissionConfig.PermissionType) - Method in class com.hazelcast.config.PermissionConfig
 
setType(IndexType) - Method in class com.hazelcast.internal.config.IndexConfigReadOnly
 
setType(ConnectionType) - Method in interface com.hazelcast.internal.nio.Connection
Sets the type of the connection
setType(ConnectionType) - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
setTypeClass(Class) - Method in class com.hazelcast.config.SerializerConfig
Sets the type of the class that will be serialized via this implementation.
setTypeClassName(String) - Method in class com.hazelcast.config.SerializerConfig
This method is called only if typeClass is not set.
setTypes(Class<K>, Class<V>) - Method in class com.hazelcast.config.AbstractCacheConfig
Sets the expected type of keys and values for a Cache configured with this Configuration.
setTypes(Class<K>, Class<V>) - Method in interface com.hazelcast.config.CacheConfiguration
Sets the expected type of keys and values for a Cache configured with this Configuration.
setTypes(Class<K>, Class<V>) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setUncommittedEntryCountToRejectNewAppends(int) - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
setUnknownCount(long) - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
 
setUnknownTime(long) - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
 
setUpdateCount(long) - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
Sets the update count of this stats to the given update count.
setUpdateCount(long) - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
Sets the update count to the given value.
setUpdateInterval(int) - Method in class com.hazelcast.config.ManagementCenterConfig
Sets the time frequency (in seconds) for which Management Center will take information from the Hazelcast cluster.
setUpdateTime(long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
setupNextDecoder() - Method in class com.hazelcast.internal.nio.tcp.SingleProtocolDecoder
 
setupNextDecoder() - Method in class com.hazelcast.internal.nio.tcp.TextHandshakeDecoder
 
setUptime(int) - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
setUriString(String) - Method in class com.hazelcast.config.CacheConfig
Sets the URI string, which is the global identifier of the ICache.
setUriString(String) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setUrl(String) - Method in class com.hazelcast.config.ManagementCenterConfig
Sets the URL where management center will work.
setUrl(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setUsage(LoginModuleConfig.LoginModuleUsage) - Method in class com.hazelcast.config.LoginModuleConfig
 
setUsedHeap(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
setUsedMetadata(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
setUsedNativeMemory(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
setUseEndpointPrivateAddress(boolean) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets whether the WAN connection manager should connect to the endpoint on the private address returned by the discovery SPI.
setUseNativeByteOrder(boolean) - Method in class com.hazelcast.config.SerializationConfig
 
setUseNativeByteOrder(boolean) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
setUseNativeByteOrder(boolean) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
setUsePublicIp(boolean) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
Decides whether the public or private IP should be used to connect to Hazelcast members.
setUserCodeDeploymentConfig(ClientUserCodeDeploymentConfig) - Method in class com.hazelcast.client.config.ClientConfig
Set User Code Deployment configuration
setUserCodeDeploymentConfig(UserCodeDeploymentConfig) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setUserCodeDeploymentConfig(UserCodeDeploymentConfig) - Method in class com.hazelcast.config.Config
Set User Code Deployment configuration
setUserCodeDeploymentConfig(UserCodeDeploymentConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setUserCodeDeploymentService(UserCodeDeploymentService) - Method in class com.hazelcast.internal.usercodedeployment.UserCodeDeploymentClassLoader
 
setUserContext(ConcurrentMap<String, Object>) - Method in class com.hazelcast.client.config.ClientConfig
 
setUserContext(ConcurrentMap<String, Object>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setUserContext(ConcurrentMap<String, Object>) - Method in class com.hazelcast.config.Config
Sets the user supplied context.
setUserContext(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setUserContext(ConcurrentMap<String, Object>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setUserData(String, Object, UserDataHandler) - Method in class com.hazelcast.internal.config.yaml.ElementAdapter
 
setUserFilter(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setUserNameAttribute(String) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
setUsernamePasswordIdentityConfig(UsernamePasswordIdentityConfig) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
setUsernamePasswordIdentityConfig(String, String) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
setUsernamePasswordIdentityConfig(UsernamePasswordIdentityConfig) - Method in class com.hazelcast.config.security.RealmConfig
 
setUsernamePasswordIdentityConfig(String, String) - Method in class com.hazelcast.config.security.RealmConfig
 
setUserSearchScope(LdapSearchScope) - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
SetUtil - Class in com.hazelcast.internal.util
Utility class for Sets.
setUuid(UUID) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataContainer
 
setUuid(int, UUID) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataGenerator
 
setUuid(UUID) - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
setUuid(UUID) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecord
 
setUuid(UUID) - Method in class com.hazelcast.map.impl.querycache.publisher.PartitionAccumulatorRegistry
 
setUuid(UUID) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
setValidateTarget(boolean) - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
setValidationTimeoutSeconds(int) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
Sets validation timeout for hot-restart process, includes validating cluster members expected to join and partition table on all cluster.
setValue(V) - Method in class com.hazelcast.cache.impl.CacheEntry
 
setValue(V) - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
setValue(Data) - Method in class com.hazelcast.cache.impl.record.CacheDataRecord
 
setValue(Object) - Method in class com.hazelcast.cache.impl.record.CacheObjectRecord
 
setValue(V) - Method in interface com.hazelcast.cache.impl.record.CacheRecord
Sets the value of this CacheRecord.
setValue(HyperLogLog) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
 
setValue(Data) - Method in class com.hazelcast.collection.impl.collection.CollectionItem
 
setValue(MemcacheEntry) - Method in class com.hazelcast.internal.ascii.memcache.GetCommand
 
setValue(byte[]) - Method in class com.hazelcast.internal.ascii.rest.RestValue
 
setValue(long) - Method in class com.hazelcast.internal.crdt.pncounter.operations.CRDTTimestampedLong
 
setValue(V) - Method in class com.hazelcast.internal.journal.DeserializingEntry
 
setValue(V) - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
setValue(V) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecord
Sets the value of this NearCacheRecord.
setValue(V) - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap.SimpleEntry
 
setValue(V) - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap.WriteThroughEntry
Set our entry's value and writes it through to the map.
setValue(V) - Method in class com.hazelcast.internal.util.scheduler.ScheduledEntry
 
setValue(Object) - Method in interface com.hazelcast.internal.yaml.MutableYamlScalar
Sets the value of the scalar node
setValue(Object) - Method in class com.hazelcast.internal.yaml.YamlScalarImpl
 
setValue(V) - Method in class com.hazelcast.map.impl.LazyMapEntry
 
setValue(V) - Method in class com.hazelcast.map.impl.MapEntrySimple
 
setValue(Data) - Method in class com.hazelcast.map.impl.query.QueryResultRow
 
setValue(Object) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
setValue(Record<Data>, Object) - Method in class com.hazelcast.map.impl.record.DataRecordFactory
 
setValue(Record<Object>, Object) - Method in class com.hazelcast.map.impl.record.ObjectRecordFactory
 
setValue(V) - Method in interface com.hazelcast.map.impl.record.Record
 
setValue(Record<T>, Object) - Method in interface com.hazelcast.map.impl.record.RecordFactory
 
setValue(V) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
setValue(long) - Method in class com.hazelcast.monitor.impl.LocalPNCounterStatsImpl
Sets the current value for the PN counter.
setValue(V) - Method in class com.hazelcast.query.impl.CachedQueryEntry
 
setValue(Object) - Method in class com.hazelcast.query.impl.QueryEntry
 
setValue(Data) - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
setValue(V) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
setValue(V, long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
setValue(V) - Method in class com.hazelcast.spi.impl.merge.AbstractCollectionMergingValueImpl
 
setValue(V) - Method in class com.hazelcast.spi.impl.merge.AbstractMergingEntryImpl
 
setValue(V) - Method in class com.hazelcast.spi.impl.merge.AbstractMergingValueImpl
 
setValue(Data) - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
setValue(Data) - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
setValue(Object) - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
setValueClassName(String) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setValueCollectionType(String) - Method in class com.hazelcast.config.MultiMapConfig
Sets the collection type for the values of this MultiMap.
setValueCollectionType(MultiMapConfig.ValueCollectionType) - Method in class com.hazelcast.config.MultiMapConfig
Sets the collection type for the values of this MultiMap.
setValueCollectionType(String) - Method in class com.hazelcast.internal.config.MultiMapConfigReadOnly
 
setValueCollectionType(MultiMapConfig.ValueCollectionType) - Method in class com.hazelcast.internal.config.MultiMapConfigReadOnly
 
setValueInternal(V, long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
setValueMetadata(Object) - Method in class com.hazelcast.query.impl.Metadata
 
setValues(Collection<Object>) - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
setValues(RingbufferMergeData) - Method in class com.hazelcast.spi.impl.merge.RingbufferMergingValueImpl
 
setValueStartLocation(int) - Method in class com.hazelcast.json.internal.JsonSchemaTerminalNode
Sets the location of the value in the underlying input.
setValueType(Class<V>) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setValueType(String) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the value type for this ICache.
setValueType(String) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setVectorClock(VectorClock) - Method in class com.hazelcast.internal.crdt.pncounter.operations.CRDTTimestampedLong
 
setVersion(byte) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
setVersion(byte) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
setVersion(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
setVersion(long) - Method in interface com.hazelcast.map.impl.record.Record
 
setVersion(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
 
setVersion(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
setVersion(long) - Method in interface com.hazelcast.map.impl.tx.MapTxnOperation
 
setVersion(long) - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
 
setVersion(long) - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
 
setVersion(long) - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
 
setVersion(Version) - Method in interface com.hazelcast.nio.VersionAware
If the serializer supports versioning it may set the version to use for the serialization on this object.
setVersion(long) - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
 
setVersion(long) - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
setWaitingRequests(int) - Method in class com.hazelcast.internal.ascii.memcache.Stats
 
setWaitTimeout(long) - Method in class com.hazelcast.spi.impl.operationservice.Operation
Sets the wait timeout in millis.
setWanConsumerConfig(WanConsumerConfig) - Method in class com.hazelcast.config.WanReplicationConfig
Sets the WAN consumer configuration for this WAN replication.
setWanProtocolVersion(Version) - Method in interface com.hazelcast.nio.WanProtocolVersionAware
Sets the WAN protocol version.
setWanReplicationConfigs(Map<String, WanReplicationConfig>) - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
setWanReplicationConfigs(Map<String, WanReplicationConfig>) - Method in class com.hazelcast.config.Config
Sets the map of WAN replication configurations, mapped by config name.
setWanReplicationConfigs(Map<String, WanReplicationConfig>) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.CacheConfig
 
setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.CacheSimpleConfig
Sets the WAN target replication reference.
setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.MapConfig
Sets the WAN target replication reference.
setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.internal.config.MapConfigReadOnly
 
setWanSyncConfig(WanSyncConfig) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
Sets the config for the WAN sync mechanism.
setWanSyncState(WanSyncState) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
setWhitelist(ClassFilter) - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
setWhitelistedPrefixes(String) - Method in class com.hazelcast.config.UserCodeDeploymentConfig
Comma-separated list of class prefixes which will be loaded remotely.
SetWithExpiryOperation - Class in com.hazelcast.map.impl.operation
 
SetWithExpiryOperation() - Constructor for class com.hazelcast.map.impl.operation.SetWithExpiryOperation
 
SetWithExpiryOperation(String, Data, Data, long, long) - Constructor for class com.hazelcast.map.impl.operation.SetWithExpiryOperation
 
setWithUncountedAccess(Data, Object, long, long) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
setWithUncountedAccess(Data, Object, long, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Does exactly the same thing as RecordStore.set(Data, Object, long, long) except the invocation is not counted as a read access while updating the access statics.
setWriteBatchSize(int) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
setWriteBatchSize(int) - Method in class com.hazelcast.config.MapStoreConfig
Sets the number of operations to be included in each batch processing round.
setWriteBatchSize(int) - Method in class com.hazelcast.internal.config.MapStoreConfigReadOnly
 
setWriteCoalescing(boolean) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
setWriteCoalescing(boolean) - Method in class com.hazelcast.config.MapStoreConfig
Setting MapStoreConfig.writeCoalescing is meaningful if you are using write-behind MapStore.
setWriteCoalescing(boolean) - Method in class com.hazelcast.internal.config.MapStoreConfigReadOnly
 
setWriteDelaySeconds(int) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.MapStoreConfigHolder
 
setWriteDelaySeconds(int) - Method in class com.hazelcast.config.MapStoreConfig
Sets the number of seconds to delay before writing (storing) the dirty records
setWriteDelaySeconds(int) - Method in class com.hazelcast.internal.config.MapStoreConfigReadOnly
 
setWriteThrough(boolean) - Method in class com.hazelcast.config.AbstractCacheConfig
 
setWriteThrough(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
Set if write-through caching should be used.
setWriteThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
Enables or disables write-through for this ICache: a write to the queue also loads the entry into the data store.
setWriteThrough(boolean) - Method in class com.hazelcast.internal.config.CacheConfigReadOnly
 
setWriteThrough(boolean) - Method in class com.hazelcast.internal.config.CacheSimpleConfigReadOnly
 
severe(String) - Method in class com.hazelcast.logging.AbstractLogger
 
severe(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
severe(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
severe(String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at Level.SEVERE.
severe(Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a throwable at the Level.SEVERE level.
severe(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the Level.SEVERE level.
shallowCopy() - Method in class com.hazelcast.cache.impl.DeferredValue
 
SHARED_JCACHE_INSTANCE_NAME - Static variable in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
Name of default HazelcastInstance which may be started when obtaining the default CachingProvider.
shiftConflictingKeys(long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
Shift all the slot-conflicting keys allocated to (and including) slot.
SHORT_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
SHORT_SIZE_IN_BYTES - Static variable in class com.hazelcast.internal.nio.Bits
Short size in bytes
ShortArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.ShortArraySerializer
 
ShortSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.ShortSerializer
 
shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
 
shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
 
shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
 
shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
 
shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
 
shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperation
 
shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
 
shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
 
shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
 
shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
 
shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
 
shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
 
shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheSetExpiryPolicyOperation
 
shouldBackup - Variable in class com.hazelcast.cardinality.impl.operations.CardinalityEstimatorBackupAwareOperation
 
shouldBackup() - Method in class com.hazelcast.cardinality.impl.operations.CardinalityEstimatorBackupAwareOperation
 
shouldBackup() - Method in class com.hazelcast.cardinality.impl.operations.MergeOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionClearOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionCompareAndRemoveOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionMergeOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.list.operations.ListRemoveOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.list.operations.ListSetOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.queue.operations.AddAllOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.queue.operations.ClearOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.queue.operations.DrainOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.queue.operations.QueueMergeOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollOperation
 
shouldBackup() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackOperation
 
shouldBackup() - Method in class com.hazelcast.cp.internal.operation.unsafe.UnsafeRaftReplicateOp
 
shouldBackup() - Method in class com.hazelcast.internal.locksupport.operations.LocalLockCleanupOperation
 
shouldBackup() - Method in class com.hazelcast.internal.locksupport.operations.LockOperation
 
shouldBackup() - Method in class com.hazelcast.internal.locksupport.operations.UnlockIfLeaseExpiredOperation
This operation runs on both primary and backup If it is running on backup we should not send a backup operation
shouldBackup() - Method in class com.hazelcast.internal.locksupport.operations.UnlockOperation
 
shouldBackup - Variable in class com.hazelcast.internal.longregister.operations.LongRegisterBackupAwareOperation
 
shouldBackup() - Method in class com.hazelcast.internal.longregister.operations.LongRegisterBackupAwareOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.AddIndexOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.BasePutOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.ClearOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.DeleteOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.EntryOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.EvictOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.MapFlushOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.MergeOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.PutIfAbsentOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.RemoveIfSameOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.RemoveOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.ReplaceOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.SetTtlOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.TryPutOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
 
shouldBackup() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
 
shouldBackup() - Method in class com.hazelcast.multimap.impl.operations.AbstractBackupAwareMultiMapOperation
 
shouldBackup() - Method in class com.hazelcast.multimap.impl.operations.ClearOperation
 
shouldBackup() - Method in class com.hazelcast.multimap.impl.operations.DeleteOperation
 
shouldBackup() - Method in class com.hazelcast.multimap.impl.operations.MergeOperation
 
shouldBackup() - Method in class com.hazelcast.multimap.impl.operations.PutOperation
 
shouldBackup() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllOperation
 
shouldBackup() - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
 
shouldBackup() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
 
shouldBackup() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
 
shouldBackup() - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
 
shouldBackup() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
 
shouldBackup() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
 
shouldBackup() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
 
shouldBackup() - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
 
shouldBackup() - Method in class com.hazelcast.ringbuffer.impl.operations.MergeOperation
 
shouldBackup() - Method in class com.hazelcast.scheduledexecutor.impl.operations.AbstractBackupAwareSchedulerOperation
 
shouldBackup() - Method in class com.hazelcast.scheduledexecutor.impl.operations.MergeOperation
 
shouldBackup() - Method in class com.hazelcast.scheduledexecutor.impl.operations.SyncStateOperation
 
shouldBackup() - Method in interface com.hazelcast.spi.impl.operationservice.BackupAwareOperation
Checks if a backup needs to be made.
shouldBackup() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
 
shouldBackup() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
 
shouldBackup() - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionOperation
 
shouldBlockReads() - Method in interface com.hazelcast.internal.locksupport.LockResource
 
shouldBlockReads(Data) - Method in interface com.hazelcast.internal.locksupport.LockStore
Return whether the reads for the specific key should be blocked (see LockStore.txnLock(Data, UUID, long, long, long, boolean)).
shouldBlockReads(Data) - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
shouldBlockReads(Data) - Method in class com.hazelcast.internal.locksupport.LockStoreProxy
 
shouldCheckSplitBrainProtection() - Method in class com.hazelcast.internal.locksupport.operations.LocalLockCleanupOperation
 
shouldCheckSplitBrainProtection() - Method in class com.hazelcast.internal.locksupport.operations.UnlockIfLeaseExpiredOperation
 
shouldCheckSplitBrainProtection() - Method in interface com.hazelcast.spi.impl.operationservice.SplitBrainProtectionCheckAwareOperation
Returns true if the split brain protection check should be performed.
shouldCloneOnEntryProcessing(int) - Method in class com.hazelcast.map.impl.MapContainer
 
shouldCompleteWithoutBackups() - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocation
 
shouldCompleteWithoutBackups() - Method in class com.hazelcast.spi.impl.operationservice.impl.BaseInvocation
 
shouldCompleteWithoutBackups() - Method in class com.hazelcast.spi.impl.operationservice.impl.Invocation
 
shouldConnectTo(Address) - Method in interface com.hazelcast.internal.nio.IOService
 
shouldConnectTo(Address) - Method in class com.hazelcast.internal.nio.NodeIOService
 
shouldDoInitialLoad() - Method in class com.hazelcast.map.impl.MapKeyLoader
Returns true if the keys are not loaded yet, promoting this key loader and resetting the loading state if necessary in the process.
shouldEvict() - Method in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
shouldEvict() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Returns true if eviction is allowed on this record-store, otherwise false
shouldFailOnIndeterminateOperationState() - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocation
 
shouldFailOnIndeterminateOperationState() - Method in class com.hazelcast.spi.impl.operationservice.impl.BaseInvocation
 
shouldFailOnIndeterminateOperationState() - Method in class com.hazelcast.spi.impl.operationservice.impl.Invocation
 
shouldFailOnIndeterminateOperationState() - Method in class com.hazelcast.spi.impl.operationservice.impl.RaftInvocation
 
shouldFailOnIndeterminateOperationState() - Method in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
Returns true if IndeterminateOperationStateException is enabled for this invocation
shouldHandle(OutOfMemoryError) - Method in class com.hazelcast.core.OutOfMemoryHandler
Decides if the OutOfMemoryError thrown will be handled by this OutOfMemoryHandler or not.
shouldHandle(OutOfMemoryError) - Method in class com.hazelcast.instance.impl.DefaultOutOfMemoryHandler
 
shouldIncludeValue() - Method in class com.hazelcast.client.impl.protocol.task.multimap.AbstractMultiMapAddEntryListenerMessageTask
 
shouldIncludeValue() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerMessageTask
 
shouldIncludeValue() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerToKeyMessageTask
 
shouldMerge(SplitBrainJoinMessage) - Method in class com.hazelcast.internal.cluster.impl.ClusterJoinManager
 
shouldNotify() - Method in class com.hazelcast.collection.impl.queue.operations.AddAllOperation
 
shouldNotify() - Method in class com.hazelcast.collection.impl.queue.operations.ClearOperation
 
shouldNotify() - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
 
shouldNotify() - Method in class com.hazelcast.collection.impl.queue.operations.DrainOperation
 
shouldNotify() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
 
shouldNotify() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
 
shouldNotify() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveOperation
 
shouldNotify() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitOperation
 
shouldNotify() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
 
shouldNotify() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollOperation
 
shouldNotify() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackOperation
 
shouldNotify() - Method in class com.hazelcast.durableexecutor.impl.operations.PutResultOperation
 
shouldNotify() - Method in class com.hazelcast.internal.locksupport.operations.UnlockOperation
 
shouldNotify() - Method in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
 
shouldNotify() - Method in class com.hazelcast.map.impl.operation.NotifyMapFlushOperation
 
shouldNotify() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
 
shouldNotify() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
 
shouldNotify() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
 
shouldNotify() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
 
shouldNotify() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
 
shouldNotify() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackOperation
 
shouldNotify() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
 
shouldNotify() - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
 
shouldNotify() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
 
shouldNotify() - Method in class com.hazelcast.scheduledexecutor.impl.operations.ResultReadyNotifyOperation
 
shouldNotify() - Method in interface com.hazelcast.spi.impl.operationservice.Notifier
 
shouldParkGetResult(String) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
shouldParkGetResult(String) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorMemberOwnedContainer
 
shouldRegister - Variable in class com.hazelcast.client.impl.protocol.codec.CacheListenerRegistrationCodec.RequestParameters
true if the listener is being registered, false if the listener is being unregistered.
shouldReply() - Method in class com.hazelcast.internal.ascii.AbstractTextCommand
 
shouldReply() - Method in class com.hazelcast.internal.ascii.memcache.DeleteCommand
 
shouldReply() - Method in class com.hazelcast.internal.ascii.memcache.IncrementCommand
 
shouldReply() - Method in class com.hazelcast.internal.ascii.memcache.SetCommand
 
shouldReply() - Method in class com.hazelcast.internal.ascii.memcache.TouchCommand
 
shouldReply() - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
 
shouldReply() - Method in interface com.hazelcast.internal.ascii.TextCommand
 
shouldReply() - Method in class com.hazelcast.internal.cluster.impl.BindMessage
 
shouldRetry() - Method in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
shouldUseGlobalIndex(MapConfig) - Method in class com.hazelcast.map.impl.MapContainer
 
shouldWait() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
 
shouldWait() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
 
shouldWait() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPeekOperation
 
shouldWait() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferOperation
 
shouldWait() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollOperation
 
shouldWait(int) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorContainer
 
shouldWait() - Method in class com.hazelcast.durableexecutor.impl.operations.RetrieveAndDisposeResultOperation
 
shouldWait() - Method in class com.hazelcast.durableexecutor.impl.operations.RetrieveResultOperation
 
shouldWait() - Method in class com.hazelcast.internal.journal.EventJournalReadOperation
On every invocation this method reads from the event journal until it has collected the minimum required number of response items.
shouldWait() - Method in class com.hazelcast.internal.locksupport.operations.LockOperation
 
shouldWait() - Method in class com.hazelcast.map.impl.operation.AwaitMapFlushOperation
 
shouldWait() - Method in class com.hazelcast.map.impl.operation.ContainsKeyOperation
 
shouldWait() - Method in class com.hazelcast.map.impl.operation.EntryOperation
 
shouldWait() - Method in class com.hazelcast.map.impl.operation.GetEntryViewOperation
 
shouldWait() - Method in class com.hazelcast.map.impl.operation.GetOperation
 
shouldWait() - Method in class com.hazelcast.map.impl.operation.LockAwareOperation
 
shouldWait() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
 
shouldWait() - Method in class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
 
shouldWait() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
 
shouldWait() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
 
shouldWait() - Method in class com.hazelcast.multimap.impl.operations.AbstractBackupAwareMultiMapOperation
 
shouldWait() - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
 
shouldWait() - Method in class com.hazelcast.multimap.impl.operations.CountOperation
 
shouldWait() - Method in class com.hazelcast.multimap.impl.operations.DeleteOperation
 
shouldWait() - Method in class com.hazelcast.multimap.impl.operations.GetAllOperation
 
shouldWait() - Method in class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
 
shouldWait() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
 
shouldWait() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
 
shouldWait() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
 
shouldWait(long) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
Returns if the sequence is one after the sequence of the newest item in the ring buffer.
shouldWait() - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetResultOperation
 
shouldWait() - Method in interface com.hazelcast.spi.impl.operationservice.BlockingOperation
 
shrinkMissingMembers(Collection<UUID>) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
SHUFFLE_MEMBER_LIST - Static variable in class com.hazelcast.client.properties.ClientProperty
Client shuffles the given member list to prevent all clients to connect to the same node when this property is set to true.
shutdown(boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
shutdown() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
 
shutdown(boolean) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorService
 
shutdown(HazelcastInstance) - Static method in class com.hazelcast.client.HazelcastClient
Shutdown the provided client and remove it from the managed list
shutdown(String) - Static method in class com.hazelcast.client.HazelcastClient
Shutdown the provided client and remove it from the managed list
shutdown(boolean) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
shutdown() - Method in class com.hazelcast.client.impl.clientside.ClientDiscoveryService
 
shutdown() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
shutdown() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
shutdown() - Method in class com.hazelcast.client.impl.clientside.LifecycleServiceImpl
 
shutdown() - Method in class com.hazelcast.client.impl.connection.ClientConnectionStrategy
This will be called as the last step of the HazelcastClient's shutdown.
shutdown() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
shutdown() - Method in class com.hazelcast.client.impl.connection.nio.ClientICMPManager
 
shutdown() - Method in interface com.hazelcast.client.impl.connection.nio.ClusterConnectorService
 
shutdown() - Method in class com.hazelcast.client.impl.connection.nio.ClusterConnectorServiceImpl
 
shutdown() - Method in class com.hazelcast.client.impl.connection.nio.DefaultClientConnectionStrategy
 
shutdown() - Method in class com.hazelcast.client.impl.connection.nio.HeartbeatManager
 
shutdown() - Method in class com.hazelcast.client.impl.proxy.ClientClusterProxy
 
shutdown(TransactionOptions) - Method in class com.hazelcast.client.impl.proxy.ClientClusterProxy
 
shutdown() - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
shutdown() - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
shutdown() - Method in class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
shutdown() - Method in class com.hazelcast.client.impl.querycache.subscriber.ClientQueryCacheScheduler
 
shutdown() - Method in class com.hazelcast.client.impl.spi.impl.AbstractClientInvocationService
 
shutdown() - Method in class com.hazelcast.client.impl.spi.impl.ClientClusterServiceImpl
 
shutdown() - Method in class com.hazelcast.client.impl.spi.impl.ClientExecutionServiceImpl
 
shutdown() - Method in class com.hazelcast.client.impl.spi.impl.ClientResponseHandlerSupplier
 
shutdown() - Method in class com.hazelcast.client.impl.spi.impl.ClientTransactionManagerServiceImpl
 
shutdown() - Method in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
shutdown() - Method in interface com.hazelcast.cluster.Cluster
Changes state of the cluster to the ClusterState.PASSIVE transactionally, then triggers the shutdown process on each node.
shutdown(TransactionOptions) - Method in interface com.hazelcast.cluster.Cluster
Changes state of the cluster to the ClusterState.PASSIVE transactionally, then triggers the shutdown process on each node.
shutdown(boolean) - Method in class com.hazelcast.collection.impl.collection.CollectionService
 
shutdown(boolean) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
shutdown() - Method in interface com.hazelcast.core.HazelcastInstance
Shuts down this HazelcastInstance.
shutdown() - Method in interface com.hazelcast.core.LifecycleService
Gracefully shuts down HazelcastInstance.
shutdown(boolean) - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueService
 
shutdown(boolean) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
shutdown(boolean) - Method in class com.hazelcast.cp.internal.RaftService
 
shutdown() - Method in class com.hazelcast.cp.internal.session.AbstractProxySessionManager
Invokes a shutdown call on server to close all existing sessions.
shutdown(boolean) - Method in class com.hazelcast.cp.internal.session.ProxySessionManagerService
 
shutdown(boolean) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
shutdown(boolean) - Method in class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
 
SHUTDOWN - Static variable in class com.hazelcast.durableexecutor.impl.DurableExecutorDataSerializerHook
 
shutdown() - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
shutdown(boolean) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
 
SHUTDOWN - Static variable in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
 
shutdown() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
shutdown(boolean) - Method in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorService
 
shutdown() - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
shutdown() - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
shutdown() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
shutdown() - Method in class com.hazelcast.instance.impl.LifecycleServiceImpl
 
shutdown(boolean) - Method in class com.hazelcast.instance.impl.Node
 
shutdown() - Method in interface com.hazelcast.instance.impl.NodeExtension
Shutdowns NodeExtension.
shutdown() - Method in class com.hazelcast.instance.impl.TerminatedLifecycleService
 
shutdown(boolean) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
shutdown() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
shutdown(TransactionOptions) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
shutdown(boolean) - Method in class com.hazelcast.internal.crdt.CRDTReplicationMigrationService
 
shutdown(boolean) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterService
 
shutdown() - Method in class com.hazelcast.internal.diagnostics.Diagnostics
 
shutdown(boolean) - Method in class com.hazelcast.internal.dynamicconfig.ClusterWideConfigurationService
 
shutdown() - Method in class com.hazelcast.internal.jmx.InstanceMBean
 
shutdown(String) - Static method in class com.hazelcast.internal.jmx.ManagementService
 
shutdown(boolean) - Method in class com.hazelcast.internal.locksupport.LockSupportServiceImpl
 
shutdown(boolean) - Method in class com.hazelcast.internal.longregister.LongRegisterService
 
shutdown() - Method in class com.hazelcast.internal.management.ManagementCenterService
 
shutdown() - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
 
shutdown(boolean) - Method in class com.hazelcast.internal.metrics.impl.MetricsService
 
shutdown() - Method in class com.hazelcast.internal.metrics.jmx.JmxPublisher
 
shutdown() - Method in interface com.hazelcast.internal.metrics.MetricsPublisher
Perform any necessary cleanup before shutdown.
shutdown() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.BatchInvalidator
 
shutdown() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidator
Shuts down this invalidator and releases used resources.
shutdown() - Method in interface com.hazelcast.internal.networking.Networking
Shuts down Networking and closes all registered channels.
shutdown() - Method in class com.hazelcast.internal.networking.nio.NioNetworking
 
shutdown() - Method in class com.hazelcast.internal.networking.nio.NioThread
 
shutdown() - Method in interface com.hazelcast.internal.nio.NetworkingService
Shutdowns the service completely.
shutdown() - Method in class com.hazelcast.internal.nio.tcp.TcpIpAcceptor
 
shutdown() - Method in class com.hazelcast.internal.nio.tcp.TcpIpNetworkingService
 
shutdown(boolean) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
shutdown(boolean) - Method in interface com.hazelcast.internal.services.ManagedService
Shuts down this service.
shutdown(boolean) - Method in class com.hazelcast.internal.usercodedeployment.UserCodeDeploymentService
 
shutdown() - Method in class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
shutdown() - Method in class com.hazelcast.internal.util.executor.StripedExecutor
Shuts down this StripedExecutor.
shutdown() - Method in class com.hazelcast.internal.util.PhoneHome
 
shutdown(boolean) - Method in class com.hazelcast.map.impl.MapManagedService
 
shutdown(boolean) - Method in class com.hazelcast.map.impl.MapService
 
shutdown() - Method in interface com.hazelcast.map.impl.MapServiceContext
Releases internal resources solely managed by Hazelcast.
shutdown() - Method in class com.hazelcast.map.impl.nearcache.MapNearCacheManager
 
shutdown() - Method in interface com.hazelcast.map.impl.querycache.QueryCacheScheduler
Shuts down this scheduler.
shutdown() - Method in class com.hazelcast.map.impl.querycache.subscriber.NodeQueryCacheScheduler
 
shutdown(boolean) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
shutdown() - Method in class com.hazelcast.replicatedmap.impl.PartitionContainer
 
shutdown(boolean) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
shutdown(boolean) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
 
shutdown(boolean) - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
SHUTDOWN - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
shutdown() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorServiceProxy
 
shutdown() - Method in interface com.hazelcast.scheduledexecutor.IScheduledExecutorService
Initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
shutdown() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
 
shutdown() - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
shutdown(boolean) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
shutdown() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
shutdown() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationThread
 
shutdown() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
Shuts down this OperationExecutor.
shutdown() - Method in class com.hazelcast.spi.impl.operationexecutor.slowoperationdetector.SlowOperationDetector
 
shutdown() - Method in class com.hazelcast.spi.impl.operationparker.impl.OperationParkerImpl
 
shutdown() - Method in class com.hazelcast.spi.impl.operationservice.impl.InboundResponseHandlerSupplier
 
shutdown() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationMonitor
 
shutdown() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
 
shutdown() - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
 
shutdown(boolean) - Method in class com.hazelcast.spi.impl.servicemanager.impl.ServiceManagerImpl
 
shutdown(boolean) - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicService
 
shutdown(boolean) - Method in class com.hazelcast.topic.impl.TopicService
 
shutdown(boolean) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
shutdown(boolean) - Method in class com.hazelcast.transaction.impl.xa.XAService
 
shutdown() - Method in interface com.hazelcast.wan.impl.WanReplicationService
Starts the shutdown process of the WAN replication service.
shutdown() - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
 
shutdown() - Method in interface com.hazelcast.wan.WanReplicationPublisher
Closes the publisher and its internal connections and shuts down other internal states.
SHUTDOWN_NODE - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
SHUTDOWN_REQUEST - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
SHUTDOWN_RESPONSE - Static variable in class com.hazelcast.internal.partition.impl.PartitionDataSerializerHook
 
shutdownAll() - Static method in class com.hazelcast.client.HazelcastClient
Shuts down all the client HazelcastInstance created in this JVM.
shutdownAll() - Static method in class com.hazelcast.core.Hazelcast
Shuts down all member HazelcastInstances running on this JVM.
shutdownAll() - Static method in class com.hazelcast.instance.impl.HazelcastInstanceFactory
 
shutdownAll(List<HazelcastInstanceProxy>) - Static method in class com.hazelcast.internal.jmx.ManagementService
 
shutdownAll() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Shuts down all running HazelcastOSGiInstances on the owner bundle.
shutdownAndAwait() - Method in class com.hazelcast.client.cp.internal.session.ClientProxySessionManager
 
ShutdownClusterRequest - Class in com.hazelcast.internal.management.request
Request coming from Management Center for shutting down the Cluster
ShutdownClusterRequest() - Constructor for class com.hazelcast.internal.management.request.ShutdownClusterRequest
 
shutdownDurableExecutor(String) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
shutdownDurableExecutor(String) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
shutdownExecutor(String, ExecutorService, ILogger) - Static method in class com.hazelcast.client.impl.spi.impl.ClientExecutionServiceImpl
 
shutdownExecutor(String) - Method in class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
 
shutdownExecutor(String) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
 
shutdownExecutor(String) - Method in class com.hazelcast.scheduledexecutor.impl.DistributedScheduledExecutorService
 
shutdownExecutor(String) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
shutdownExecutor(String) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
shutdownHazelcastInstance(HazelcastOSGiInstance) - Method in interface com.hazelcast.osgi.HazelcastOSGiService
Shuts down the given HazelcastOSGiInstance on the owner bundle.
SHUTDOWNHOOK_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SHUTDOWNHOOK_POLICY - Static variable in class com.hazelcast.spi.properties.GroupProperty
Behaviour when JVM is about to exit while Hazelcast instance is still running.
shutdownImpl(boolean) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
Subclasses can implement their custom shutdown logic here
shutdownInvocations() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
Shuts down invocation infrastructure.
shutdownNodeByFiringEvents(Node, boolean) - Static method in class com.hazelcast.instance.impl.NodeShutdownHelper
Shutdowns a node by firing lifecycle events.
ShutdownNodeOp - Class in com.hazelcast.internal.cluster.impl.operations
 
ShutdownNodeOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.ShutdownNodeOp
 
shutdownNow() - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
shutdownNow() - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
shutdownNow() - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
shutdownNow() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
shutdownNow() - Method in class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
ShutdownOperation - Class in com.hazelcast.durableexecutor.impl.operations
 
ShutdownOperation() - Constructor for class com.hazelcast.durableexecutor.impl.operations.ShutdownOperation
 
ShutdownOperation(String) - Constructor for class com.hazelcast.durableexecutor.impl.operations.ShutdownOperation
 
ShutdownOperation - Class in com.hazelcast.executor.impl.operations
 
ShutdownOperation() - Constructor for class com.hazelcast.executor.impl.operations.ShutdownOperation
 
ShutdownOperation(String) - Constructor for class com.hazelcast.executor.impl.operations.ShutdownOperation
 
ShutdownOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
ShutdownOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.ShutdownOperation
 
ShutdownOperation(String) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.ShutdownOperation
 
shutdownOperationExecutor() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
ShutdownRequestOperation - Class in com.hazelcast.internal.partition.operation
 
ShutdownRequestOperation() - Constructor for class com.hazelcast.internal.partition.operation.ShutdownRequestOperation
 
ShutdownResponseOperation - Class in com.hazelcast.internal.partition.operation
 
ShutdownResponseOperation() - Constructor for class com.hazelcast.internal.partition.operation.ShutdownResponseOperation
 
shutdownScheduledDurableExecutor(String) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
shutdownScheduledDurableExecutor(String) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
signalMigrationComplete() - Method in class com.hazelcast.internal.networking.nio.iobalancer.IOBalancer
 
signalProtocolLoaded() - Method in class com.hazelcast.internal.nio.tcp.MemberProtocolEncoder
 
SilentException - Interface in com.hazelcast.spi.exception
Marked interface for exceptions.
SIMPLE_CACHE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SIMPLE_CACHE_CONFIG_DURATION_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SIMPLE_CACHE_CONFIG_EXPIRY_POLICY_FACTORY_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SIMPLE_CACHE_CONFIG_TIMED_EXPIRY_POLICY_FACTORY_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SIMPLE_CACHE_ENTRY_LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SIMPLE_TOKEN_CRED - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
 
SimpleCommand - Class in com.hazelcast.internal.ascii.memcache
 
SimpleCommand(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.internal.ascii.memcache.SimpleCommand
 
SimpleCommandParser - Class in com.hazelcast.internal.ascii.memcache
 
SimpleCommandParser(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.internal.ascii.memcache.SimpleCommandParser
 
SimpleCommandProcessor - Class in com.hazelcast.internal.ascii.memcache
 
SimpleCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.memcache.SimpleCommandProcessor
 
SimpleDiscoveryNode - Class in com.hazelcast.spi.discovery
Simple immutable implementation of the DiscoveryNode interface for convenience when implementing a DiscoveryStrategy.
SimpleDiscoveryNode(Address) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
This constructor will set private and public addresses to the same value and no properties are available.
SimpleDiscoveryNode(Address, Map<String, String>) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
This constructor will set private and public addresses to the same value.
SimpleDiscoveryNode(Address, Address) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
This constructor will set private and public addresses separately and no properties are available.
SimpleDiscoveryNode(Address, Address, Map<String, String>) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
This constructor will set private and public addresses separately.
SimpleEntry(K, V) - Constructor for class com.hazelcast.internal.util.ConcurrentReferenceHashMap.SimpleEntry
 
SimpleEntry(Map.Entry<? extends K, ? extends V>) - Constructor for class com.hazelcast.internal.util.ConcurrentReferenceHashMap.SimpleEntry
 
SimpleEntryView<K,V> - Class in com.hazelcast.map.impl
SimpleEntryView is an implementation of EntryView and also it is writable.
SimpleEntryView(K, V) - Constructor for class com.hazelcast.map.impl.SimpleEntryView
 
SimpleEntryView() - Constructor for class com.hazelcast.map.impl.SimpleEntryView
 
SimpleEntryViewCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
SimpleExecutionCallback<E> - Class in com.hazelcast.spi.impl
A ExecutionCallback implementation that simplifies the implementation of the ExecutionCallback by only needing to implement a single method.
SimpleExecutionCallback() - Constructor for class com.hazelcast.spi.impl.SimpleExecutionCallback
 
simpleName - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetConfigCodec.RequestParameters
Name of the cache without prefix.
SimplePropertyDefinition - Class in com.hazelcast.config.properties
Simple immutable implementation of PropertyDefinition for convenience of implementors.
SimplePropertyDefinition(String, TypeConverter) - Constructor for class com.hazelcast.config.properties.SimplePropertyDefinition
 
SimplePropertyDefinition(String, boolean, TypeConverter) - Constructor for class com.hazelcast.config.properties.SimplePropertyDefinition
 
SimplePropertyDefinition(String, boolean, TypeConverter, ValueValidator) - Constructor for class com.hazelcast.config.properties.SimplePropertyDefinition
 
SimpleTokenCredentials - Class in com.hazelcast.security
Simple implementation of Credentials using a raw byte array token.
SimpleTokenCredentials() - Constructor for class com.hazelcast.security.SimpleTokenCredentials
 
SimpleTokenCredentials(byte[]) - Constructor for class com.hazelcast.security.SimpleTokenCredentials
 
SimulateLoadTask - Class in com.hazelcast.console
A simulated load test.
SimulateLoadTask(int, int, String) - Constructor for class com.hazelcast.console.SimulateLoadTask
 
SINGLE_ATTRIBUTE - Static variable in class com.hazelcast.projection.impl.ProjectionDataSerializerHook
 
singleAttribute(String) - Static method in class com.hazelcast.projection.Projections
Returns a projection that extracts the value of the given attributePath.
SingleAttributeProjection<I,O> - Class in com.hazelcast.projection.impl
Projection that extracts the values of the given attribute and returns it.
SingleAttributeProjection(String) - Constructor for class com.hazelcast.projection.impl.SingleAttributeProjection
 
SingleExecutorThreadFactory - Class in com.hazelcast.internal.util.executor
 
SingleExecutorThreadFactory(ClassLoader, String) - Constructor for class com.hazelcast.internal.util.executor.SingleExecutorThreadFactory
 
SingleIMapEvent - Class in com.hazelcast.map.impl.querycache.event
SingleIMapEvent(QueryCacheEventData) - Constructor for class com.hazelcast.map.impl.querycache.event.SingleIMapEvent
 
singleLine() - Static method in class com.hazelcast.internal.json.PrettyPrint
Print every value on a separate line.
SingleMemberGroup - Class in com.hazelcast.partition.membergroup
 
SingleMemberGroup() - Constructor for class com.hazelcast.partition.membergroup.SingleMemberGroup
 
SingleMemberGroup(Member) - Constructor for class com.hazelcast.partition.membergroup.SingleMemberGroup
 
SingleMemberGroupFactory - Class in com.hazelcast.partition.membergroup
Arranges members in single-member groups (every member is its own group).
SingleMemberGroupFactory() - Constructor for class com.hazelcast.partition.membergroup.SingleMemberGroupFactory
 
SingleNearCacheInvalidation - Class in com.hazelcast.internal.nearcache.impl.invalidation
Represents a single key invalidation.
SingleNearCacheInvalidation() - Constructor for class com.hazelcast.internal.nearcache.impl.invalidation.SingleNearCacheInvalidation
 
SingleNearCacheInvalidation(Data, String, UUID, UUID, long) - Constructor for class com.hazelcast.internal.nearcache.impl.invalidation.SingleNearCacheInvalidation
 
SingleProtocolDecoder - Class in com.hazelcast.internal.nio.tcp
 
SingleProtocolDecoder(ProtocolType, InboundHandler) - Constructor for class com.hazelcast.internal.nio.tcp.SingleProtocolDecoder
 
SingleProtocolDecoder(ProtocolType, InboundHandler[], MemberProtocolEncoder) - Constructor for class com.hazelcast.internal.nio.tcp.SingleProtocolDecoder
Decodes first 3 incoming bytes, validates against supportedProtocol and, when matching, replaces itself in the inbound pipeline with the next InboundHandlers.
SingleResultSet - Class in com.hazelcast.query.impl
Multiple result set for Predicates.
SingleResultSet(Map<Data, QueryableEntry>) - Constructor for class com.hazelcast.query.impl.SingleResultSet
 
singletonPartitionIdSet(int, int) - Static method in class com.hazelcast.internal.util.SetUtil
 
size() - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
size() - Method in interface com.hazelcast.cache.ICache
Total entry count.
size() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
SIZE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
size() - Method in class com.hazelcast.cache.impl.CacheProxy
 
size() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Calculates the entry size of this store which reflects the partition size of the cache.
size() - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
size() - Method in interface com.hazelcast.client.impl.ClientEndpointManager
Returns the current number of endpoints.
size() - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
 
size() - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
size() - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
size() - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
size() - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
size() - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
size() - Method in class com.hazelcast.client.impl.proxy.ClientRingbufferProxy
 
size() - Method in class com.hazelcast.client.impl.proxy.ClientSetProxy
 
size() - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnListProxy
 
size() - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
size() - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMultiMapProxy
 
size() - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnQueueProxy
 
size() - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnSetProxy
 
size() - Method in interface com.hazelcast.collection.BaseQueue
Returns the number of elements in this collection.
size() - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
size() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
size() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
 
SIZE - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
size() - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
 
size() - Method in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxySupport
 
size - Variable in class com.hazelcast.config.EvictionConfig
 
size() - Method in interface com.hazelcast.internal.adapter.DataStructureAdapter
 
size() - Method in class com.hazelcast.internal.adapter.ICacheDataStructureAdapter
 
size() - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
size() - Method in class com.hazelcast.internal.adapter.ReplicatedMapDataStructureAdapter
 
size() - Method in class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
size(String) - Method in interface com.hazelcast.internal.ascii.TextCommandService
Returns the size of the distributed queue instance with the specified name
size(String) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
size() - Method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
 
size() - Method in class com.hazelcast.internal.cluster.impl.MembersView
 
size() - Method in class com.hazelcast.internal.dynamicconfig.AggregatingMap
 
size() - Method in class com.hazelcast.internal.json.JsonArray
Returns the number of elements in this array.
size() - Method in class com.hazelcast.internal.json.JsonObject
Returns the number of members (name/value pairs) in this object.
size() - Method in class com.hazelcast.internal.metrics.managementcenter.ConcurrentArrayRingbuffer
 
size() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
size() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationQueue
 
size() - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
size() - Method in interface com.hazelcast.internal.nearcache.NearCache
Gets the count of stored records.
size() - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
Gets the number of stored records.
size() - Method in class com.hazelcast.internal.util.collection.BiInt2ObjectMap
Return the number of unique entries in the map.
size() - Method in class com.hazelcast.internal.util.collection.InflatableSet
 
size() - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap.KeySet
 
size() - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
 
size() - Method in class com.hazelcast.internal.util.collection.IntHashSet
 
size() - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
 
size() - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
 
size() - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
 
size() - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap.KeySet
 
size() - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
 
size() - Method in class com.hazelcast.internal.util.collection.LongHashSet
size() - Method in interface com.hazelcast.internal.util.collection.LongSet
 
size() - Method in class com.hazelcast.internal.util.collection.LongSetHsa
 
size() - Method in class com.hazelcast.internal.util.collection.MapDelegatingSet
size() - Method in class com.hazelcast.internal.util.collection.OAHashSet
 
size() - Method in class com.hazelcast.internal.util.collection.PartitionIdSet
 
size() - Method in class com.hazelcast.internal.util.collection.WeightedEvictableList
 
size() - Method in class com.hazelcast.internal.util.concurrent.MPSCQueue
.
size() - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
Returns the number of key-value mappings in this map.
size() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray
 
size() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
size() - Method in class com.hazelcast.internal.util.ResultSet
 
size() - Method in interface com.hazelcast.map.BaseMap
Returns the number of entries in this map.
SIZE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
size() - Method in class com.hazelcast.map.impl.MapEntries
 
size() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
Returns the number of elements in this WriteBehindQueue.
size() - Method in class com.hazelcast.map.impl.query.QueryResult
 
size() - Method in class com.hazelcast.map.impl.query.QueryResultCollection
 
size() - Method in interface com.hazelcast.map.impl.querycache.accumulator.Accumulator
Current size of accumulator.
size() - Method in class com.hazelcast.map.impl.querycache.accumulator.BasicAccumulator
 
size() - Method in interface com.hazelcast.map.impl.querycache.accumulator.CyclicBuffer
Returns the size of unread events in this buffer according to the current head.
size() - Method in class com.hazelcast.map.impl.querycache.accumulator.DefaultCyclicBuffer
 
size() - Method in class com.hazelcast.map.impl.querycache.event.BatchEventData
 
size() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
size() - Method in interface com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordStore
 
size() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
Size may not give precise size at a specific moment due to the expiration logic.
size() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
size() - Method in interface com.hazelcast.map.impl.recordstore.Storage
 
size() - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
size() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
size() - Method in interface com.hazelcast.map.QueryCache
 
size() - Method in interface com.hazelcast.multimap.BaseMultiMap
Returns the number of key-value pairs in the multimap.
size() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
SIZE - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
size() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
size() - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
 
size() - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
 
size() - Method in interface com.hazelcast.multimap.MultiMap
Returns the number of key-value pairs in the multimap.
size() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
size() - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
size() - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
size() - Method in class com.hazelcast.query.impl.AndResultSet
 
size() - Method in class com.hazelcast.query.impl.DuplicateDetectingMultiResult
 
size() - Method in class com.hazelcast.query.impl.FastMultiResultSet
 
size() - Method in class com.hazelcast.query.impl.OrResultSet
 
size() - Method in class com.hazelcast.query.impl.SingleResultSet
 
size() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
 
SIZE - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
size() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
size() - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
 
size() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
size() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
size() - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
 
size() - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
 
size() - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
 
size() - Method in interface com.hazelcast.ringbuffer.impl.Ringbuffer
Returns number of items in the ringbuffer (meaning the number of items between the Ringbuffer.headSequence() and Ringbuffer.tailSequence()).
size() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
 
size() - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
 
size() - Method in interface com.hazelcast.ringbuffer.ReadResultSet
Return the result set size.
size() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Returns number of items in the Ringbuffer.
size() - Method in interface com.hazelcast.spi.impl.operationexecutor.impl.OperationQueue
Returns the total number of pending operations.
size() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationQueueImpl
 
size() - Method in class com.hazelcast.spi.impl.operationparker.impl.WaitSet
 
size() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
Returns the number of pending invocations.
size() - Method in class com.hazelcast.spi.impl.SerializableList
 
size() - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
 
size() - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Returns number of items in the ringbuffer (meaning the number of items between the RingbufferMergeData.getHeadSequence() and RingbufferMergeData.getTailSequence()).
size() - Method in class com.hazelcast.transaction.impl.TransactionLog
Returns the number of TransactionRecords in this TransactionLog.
size() - Method in interface com.hazelcast.transaction.TransactionalList
Returns the size of the list.
size() - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of Map.size().
size() - Method in interface com.hazelcast.transaction.TransactionalMultiMap
Returns the number of key-value pairs in the multimap.
size() - Method in interface com.hazelcast.transaction.TransactionalQueue
Returns the number of elements in this collection.
size() - Method in interface com.hazelcast.transaction.TransactionalSet
Returns the size of the set.
SIZE_FACTORY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
SIZE_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
SIZE_OF_FRAME_LENGTH_AND_FLAGS - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
SIZE_OFFSET - Static variable in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
SizeOperation - Class in com.hazelcast.collection.impl.queue.operations
Notify size of the queue.
SizeOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.SizeOperation
 
SizeOperation(String) - Constructor for class com.hazelcast.collection.impl.queue.operations.SizeOperation
 
SizeOperation - Class in com.hazelcast.multimap.impl.operations
 
SizeOperation() - Constructor for class com.hazelcast.multimap.impl.operations.SizeOperation
 
SizeOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.SizeOperation
 
SizeOperation - Class in com.hazelcast.replicatedmap.impl.operation
 
SizeOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.SizeOperation
 
SizeOperation(String) - Constructor for class com.hazelcast.replicatedmap.impl.operation.SizeOperation
 
SizeOperationFactory - Class in com.hazelcast.map.impl.operation
 
SizeOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.SizeOperationFactory
 
SizeOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.SizeOperationFactory
 
skip(long) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
skipBytes(int) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
 
SkipIndexPredicate - Class in com.hazelcast.query.impl.predicates
The SkipIndexPredicate is a predicate that prevents an index from being used on the wrapped predicate.
SkipIndexPredicate(Predicate) - Constructor for class com.hazelcast.query.impl.predicates.SkipIndexPredicate
 
Slf4jFactory - Class in com.hazelcast.logging
 
Slf4jFactory() - Constructor for class com.hazelcast.logging.Slf4jFactory
 
SlotAssignmentResult - Interface in com.hazelcast.internal.util.hashslot
An object that carries information about the result of a slot assignment invocation.
SlotAssignmentResultImpl - Class in com.hazelcast.internal.util.hashslot.impl
POJO implementation of the result of a slot assignment invocation.
SlotAssignmentResultImpl() - Constructor for class com.hazelcast.internal.util.hashslot.impl.SlotAssignmentResultImpl
 
slotBase(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
slotHash(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
slotLength - Variable in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
Total length of an array slot in bytes.
SLOW_MAX_COUNT - Static variable in class com.hazelcast.internal.diagnostics.InvocationPlugin
The maximum number of slow invocations to print.
SLOW_OPERATION_DETECTOR_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Enables or disables the SlowOperationDetector.
SLOW_OPERATION_DETECTOR_LOG_PURGE_INTERVAL_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Purge interval for slow operation logs.
SLOW_OPERATION_DETECTOR_LOG_RETENTION_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
This value defines the retention time of invocations in slow operation logs.
SLOW_OPERATION_DETECTOR_STACK_TRACE_LOGGING_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines if the stacktraces of slow operations are logged in the log file.
SLOW_OPERATION_DETECTOR_THRESHOLD_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
Defines a threshold above which a running operation in OperationService is considered to be slow.
SLOW_THRESHOLD_SECONDS - Static variable in class com.hazelcast.internal.diagnostics.InvocationPlugin
The threshold in seconds to consider an invocation to be slow.
SlowOperationDetector - Class in com.hazelcast.spi.impl.operationexecutor.slowoperationdetector
Monitors the OperationRunner instances of the OperationExecutor to see if operations are slow.
SlowOperationDetector(LoggingService, OperationRunner[], OperationRunner[], HazelcastProperties, String) - Constructor for class com.hazelcast.spi.impl.operationexecutor.slowoperationdetector.SlowOperationDetector
 
SlowOperationDTO - Class in com.hazelcast.internal.management.dto
A Serializable DTO for SlowOperationLog.
SlowOperationDTO() - Constructor for class com.hazelcast.internal.management.dto.SlowOperationDTO
 
SlowOperationDTO(String, String, int, List<SlowOperationInvocationDTO>) - Constructor for class com.hazelcast.internal.management.dto.SlowOperationDTO
 
SlowOperationInvocationDTO - Class in com.hazelcast.internal.management.dto
A Serializable DTO for SlowOperationLog.Invocation.
SlowOperationInvocationDTO() - Constructor for class com.hazelcast.internal.management.dto.SlowOperationInvocationDTO
 
SlowOperationInvocationDTO(int, String, long, int) - Constructor for class com.hazelcast.internal.management.dto.SlowOperationInvocationDTO
 
SlowOperationPlugin - Class in com.hazelcast.internal.diagnostics
A DiagnosticsPlugin that displays the slow executing operations.
SlowOperationPlugin(NodeEngineImpl) - Constructor for class com.hazelcast.internal.diagnostics.SlowOperationPlugin
 
SmartClientInvocationService - Class in com.hazelcast.client.impl.spi.impl
 
SmartClientInvocationService(HazelcastClientInstanceImpl, LoadBalancer) - Constructor for class com.hazelcast.client.impl.spi.impl.SmartClientInvocationService
 
SmartClientInvocationService.BackupEventHandler - Class in com.hazelcast.client.impl.spi.impl
 
SmartClientListenerService - Class in com.hazelcast.client.impl.spi.impl.listener
 
SmartClientListenerService(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.impl.spi.impl.listener.SmartClientListenerService
 
SNAPSHOT - Static variable in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongDataSerializerHook
 
SNAPSHOT - Static variable in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefDataSerializerHook
 
snapshot() - Method in class com.hazelcast.cp.internal.raft.impl.dto.InstallSnapshot
 
snapshot() - Method in class com.hazelcast.cp.internal.raft.impl.log.RaftLog
Returns snapshot entry.
snapshot() - Method in class com.hazelcast.cp.internal.raft.impl.persistence.RestoredRaftState
 
snapshot() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskStatisticsImpl
 
SNAPSHOT_ENTRY - Static variable in class com.hazelcast.cp.internal.raft.impl.RaftDataSerializerHook
 
SnapshotAwareService<T> - Interface in com.hazelcast.cp.internal.raft
The service interface required to be implemented by services that behave as a Raft state machine.
SnapshotEntry - Class in com.hazelcast.cp.internal.raft.impl.log
Represents a snapshot in the RaftLog.
SnapshotEntry() - Constructor for class com.hazelcast.cp.internal.raft.impl.log.SnapshotEntry
 
SnapshotEntry(int, long, Object, long, Collection<RaftEndpoint>) - Constructor for class com.hazelcast.cp.internal.raft.impl.log.SnapshotEntry
 
snapshotIndex() - Method in class com.hazelcast.cp.internal.raft.impl.log.RaftLog
Returns snapshot entry index.
snapshotIndex - Variable in class com.hazelcast.cp.internal.RaftNodeMetrics
 
sneakyThrow(Throwable) - Static method in class com.hazelcast.internal.util.ExceptionUtil
 
SO_KEEPALIVE - Static variable in class com.hazelcast.internal.networking.ChannelOption
SO_LINGER - Static variable in class com.hazelcast.internal.networking.ChannelOption
SO_RCVBUF - Static variable in class com.hazelcast.internal.networking.ChannelOption
SO_REUSEADDR - Static variable in class com.hazelcast.internal.networking.ChannelOption
SO_SNDBUF - Static variable in class com.hazelcast.internal.networking.ChannelOption
SO_TIMEOUT - Static variable in class com.hazelcast.internal.networking.ChannelOption
SOCKET - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
socket() - Method in class com.hazelcast.internal.networking.AbstractChannel
 
socket() - Method in interface com.hazelcast.internal.networking.Channel
 
SOCKET_BIND_ANY - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_BUFFER_DIRECT - Static variable in class com.hazelcast.spi.properties.GroupProperty
If the bytebuffers used in the socket should be a direct bytebuffer (true) or a regular bytebuffer (false).
SOCKET_CLIENT_BIND - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_CLIENT_BIND_ANY - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_CLIENT_BUFFER_DIRECT - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_CLIENT_RECEIVE_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Overrides receive buffer size for connections opened by clients.
SOCKET_CLIENT_SEND_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
Overrides send buffer size for connections opened by clients.
SOCKET_CONNECT_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_KEEP_ALIVE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_LINGER_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_NO_DELAY - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_RECEIVE_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_SEND_BUFFER_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
SOCKET_SERVER_BIND_ANY - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
socketChannel - Variable in class com.hazelcast.internal.networking.AbstractChannel
 
socketChannel() - Method in class com.hazelcast.internal.networking.AbstractChannel
 
socketChannel - Variable in class com.hazelcast.internal.networking.nio.NioPipeline
 
SocketInterceptor - Interface in com.hazelcast.nio
An interface that provides the ability to intercept the creation of sockets.
socketInterceptorConfig - Variable in class com.hazelcast.config.EndpointConfig
 
SocketInterceptorConfig - Class in com.hazelcast.config
Contains the configuration for interceptor socket.
SocketInterceptorConfig() - Constructor for class com.hazelcast.config.SocketInterceptorConfig
 
SocketInterceptorConfig(SocketInterceptorConfig) - Constructor for class com.hazelcast.config.SocketInterceptorConfig
 
SocketOptions - Class in com.hazelcast.client.config
TCP Socket options
SocketOptions() - Constructor for class com.hazelcast.client.config.SocketOptions
 
SocketOptions(SocketOptions) - Constructor for class com.hazelcast.client.config.SocketOptions
 
softFlush() - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
Only marks this MapDataStore as flush-able.
softFlush() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
softFlush() - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
softFlush() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
softFlush() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
sort(long, long) - Method in class com.hazelcast.internal.util.sort.QuickSorter
Sort the part of the array that starts at the supplied index and has the supplied length.
SortingUtil - Class in com.hazelcast.internal.util
Utility class for generating Comparators to be used in sort methods specific to hazelcast classes.
sortPartitionContainers(List<CachePartitionSegment>) - Method in class com.hazelcast.cache.impl.eviction.CacheClearExpiredRecordsTask
 
sortPartitionContainers(List<T>) - Method in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
sortPartitionContainers(List<PartitionContainer>) - Method in class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
 
SOURCE_NOT_AVAILABLE - Static variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
SPACE - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
 
SparseHyperLogLogEncoder - Class in com.hazelcast.cardinality.impl.hyperloglog.impl
1.
SparseHyperLogLogEncoder() - Constructor for class com.hazelcast.cardinality.impl.hyperloglog.impl.SparseHyperLogLogEncoder
 
SPI_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
SPI_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
SPI_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
SPI_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
SPIAwareMemberGroupFactory - Class in com.hazelcast.partition.membergroup
SPIAwareMemberGroupFactory is responsible for providing custom MemberGroups implemented by the user in DiscoveryStrategy.getPartitionGroupStrategy() to the PartitionStateManager.
SPIAwareMemberGroupFactory(DiscoveryService) - Constructor for class com.hazelcast.partition.membergroup.SPIAwareMemberGroupFactory
 
SpiDataSerializerHook - Class in com.hazelcast.spi.impl
 
SpiDataSerializerHook() - Constructor for class com.hazelcast.spi.impl.SpiDataSerializerHook
 
SpiPortableHook - Class in com.hazelcast.spi.impl
 
SpiPortableHook() - Constructor for class com.hazelcast.spi.impl.SpiPortableHook
 
split(String) - Static method in class com.hazelcast.client.impl.statistics.Statistics
This method uses ',' character by default.
split(String, int, char) - Static method in class com.hazelcast.client.impl.statistics.Statistics
 
SPLIT_BRAIN_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
SPLIT_BRAIN_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
SPLIT_BRAIN_HANDLER_EXECUTOR_NAME - Static variable in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
SPLIT_BRAIN_JOIN_MESSAGE - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
SPLIT_BRAIN_MERGE_VALIDATION - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
SPLIT_BRAIN_PROTECTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
SPLIT_BRAIN_PROTECTION_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SPLIT_BRAIN_PROTECTION_LISTENER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
SplitBrainDataSerializerHook - Class in com.hazelcast.spi.impl.merge
Contains all the ID hooks for IdentifiedDataSerializable classes used by the split-brain framework.
SplitBrainDataSerializerHook() - Constructor for class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
splitBrainHandlerService - Variable in class com.hazelcast.cache.impl.AbstractCacheService
 
SplitBrainHandlerService - Interface in com.hazelcast.internal.services
An interface that can be implemented by SPI services that want to be able to resolve a split-brain.
splitBrainHandlerService - Variable in class com.hazelcast.map.impl.MapService
 
SplitBrainJoinMessage - Class in com.hazelcast.internal.cluster.impl
A JoinMessage issued by the master node of a subcluster to the master of another subcluster while searching for other clusters for split brain recovery.
SplitBrainJoinMessage() - Constructor for class com.hazelcast.internal.cluster.impl.SplitBrainJoinMessage
 
SplitBrainJoinMessage(byte, int, MemberVersion, Address, UUID, boolean, ConfigCheck, Collection<Address>, int, Version, int) - Constructor for class com.hazelcast.internal.cluster.impl.SplitBrainJoinMessage
 
SplitBrainJoinMessage.SplitBrainMergeCheckResult - Enum in com.hazelcast.internal.cluster.impl
 
SplitBrainMergePolicy<V,T extends MergingValue<V>> - Interface in com.hazelcast.spi.merge
Policy for merging data structure values after a split-brain has been healed.
SplitBrainMergePolicyProvider - Class in com.hazelcast.spi.merge
A provider for SplitBrainMergePolicy instances.
SplitBrainMergePolicyProvider(NodeEngine) - Constructor for class com.hazelcast.spi.merge.SplitBrainMergePolicyProvider
Constructs a new provider for SplitBrainMergePolicy classes.
SplitBrainMergeTypeProvider<T extends MergingValue> - Interface in com.hazelcast.spi.merge
Returns a class with the provided merge value types.
SplitBrainMergeTypes - Class in com.hazelcast.spi.merge
Collection of interfaces which define the provided merge types for each data structure.
SplitBrainMergeTypes() - Constructor for class com.hazelcast.spi.merge.SplitBrainMergeTypes
 
SplitBrainMergeTypes.AtomicLongMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of IAtomicLong.
SplitBrainMergeTypes.AtomicReferenceMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of IAtomicReference.
SplitBrainMergeTypes.CacheMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of ICache.
SplitBrainMergeTypes.CardinalityEstimatorMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of CardinalityEstimator.
SplitBrainMergeTypes.CollectionMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of collections (ISet and IList).
SplitBrainMergeTypes.MapMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of IMap.
SplitBrainMergeTypes.MultiMapMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of MultiMap.
SplitBrainMergeTypes.QueueMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of IQueue.
SplitBrainMergeTypes.ReplicatedMapMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of ReplicatedMap.
SplitBrainMergeTypes.RingbufferMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of Ringbuffer.
SplitBrainMergeTypes.ScheduledExecutorMergeTypes - Interface in com.hazelcast.spi.merge
Provided merge types of IScheduledExecutorService.
SplitBrainMergeValidationOp - Class in com.hazelcast.internal.cluster.impl.operations
Validate whether clusters may merge to recover from a split brain, based on configuration & cluster version.
SplitBrainMergeValidationOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.SplitBrainMergeValidationOp
 
SplitBrainMergeValidationOp(SplitBrainJoinMessage) - Constructor for class com.hazelcast.internal.cluster.impl.operations.SplitBrainMergeValidationOp
 
SplitBrainMulticastListener - Class in com.hazelcast.internal.cluster.impl
Listens for SplitBrainJoinMessages and adds them for processing by split brain handler.
SplitBrainMulticastListener(Node, BlockingDeque<SplitBrainJoinMessage>) - Constructor for class com.hazelcast.internal.cluster.impl.SplitBrainMulticastListener
 
SplitBrainProtection - Interface in com.hazelcast.splitbrainprotection
SplitBrainProtection provides access to the current status of a split brain protection.
SplitBrainProtectionAwareService - Interface in com.hazelcast.internal.services
Split brain protection service can ask for split brain protection information to the SplitBrainProtectionAwareService to decide whether operation participates into a split brain protection or not.
splitBrainProtectionAwareService - Variable in class com.hazelcast.map.impl.MapService
 
SplitBrainProtectionCheckAwareOperation - Interface in com.hazelcast.spi.impl.operationservice
Marker interface for operations which need to control whether the check for split brain protection will be performed.
SplitBrainProtectionConfig - Class in com.hazelcast.config
Configuration for cluster split brain protection, a means to protect consistency of data from network partitions.
SplitBrainProtectionConfig() - Constructor for class com.hazelcast.config.SplitBrainProtectionConfig
 
SplitBrainProtectionConfig(String, boolean) - Constructor for class com.hazelcast.config.SplitBrainProtectionConfig
 
SplitBrainProtectionConfig(String, boolean, int) - Constructor for class com.hazelcast.config.SplitBrainProtectionConfig
 
SplitBrainProtectionConfig(SplitBrainProtectionConfig) - Constructor for class com.hazelcast.config.SplitBrainProtectionConfig
 
SplitBrainProtectionConfigBuilder - Class in com.hazelcast.config
Commons for split brain protection config builders.
SplitBrainProtectionConfigBuilder() - Constructor for class com.hazelcast.config.SplitBrainProtectionConfigBuilder
 
SplitBrainProtectionEvent - Class in com.hazelcast.splitbrainprotection
An Event that is send when a SplitBrainProtection changes.
SplitBrainProtectionEvent(Object, int, Collection<Member>, boolean) - Constructor for class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
 
SplitBrainProtectionException - Exception in com.hazelcast.splitbrainprotection
An exception thrown when the cluster size is below the defined threshold.
SplitBrainProtectionException(String) - Constructor for exception com.hazelcast.splitbrainprotection.SplitBrainProtectionException
 
SplitBrainProtectionFunction - Interface in com.hazelcast.splitbrainprotection
A function that can be used to conclude whether the minimum cluster size property is satisfied? The split brain protection function is consulted:
When a cluster membership change occurs (member added or removed) Whenever a hearbeat is received from a member, in case the SplitBrainProtectionFunction also implements HeartbeatAware A SplitBrainProtectionFunction that implements HeartbeatAware will be also notified of heartbeats.
SplitBrainProtectionImpl - Class in com.hazelcast.splitbrainprotection.impl
SplitBrainProtectionImpl can be used to notify split brain protection service for a particular split brain protection result that originated externally.
SplitBrainProtectionListener - Interface in com.hazelcast.splitbrainprotection
Listener to get notified when a split brain protection state is changed
SplitBrainProtectionListenerConfig - Class in com.hazelcast.config
Configuration class for SplitBrainProtectionListener
SplitBrainProtectionListenerConfig() - Constructor for class com.hazelcast.config.SplitBrainProtectionListenerConfig
 
SplitBrainProtectionListenerConfig(String) - Constructor for class com.hazelcast.config.SplitBrainProtectionListenerConfig
 
SplitBrainProtectionListenerConfig(SplitBrainProtectionListener) - Constructor for class com.hazelcast.config.SplitBrainProtectionListenerConfig
 
splitBrainProtectionName - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
name of an existing configured split brain protection to be used to determine the minimum number of members required in the cluster for the cache to remain functional.
splitBrainProtectionName - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCardinalityEstimatorConfigCodec.RequestParameters
name of an existing configured split brain protection to be used to determine the minimum number of members required in the cluster for the lock to remain functional.
splitBrainProtectionName - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddDurableExecutorConfigCodec.RequestParameters
name of an existing configured split brain protection to be used to determine the minimum number of members required in the cluster for the lock to remain functional.
splitBrainProtectionName - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddExecutorConfigCodec.RequestParameters
name of an existing configured split brain protection to be used to determine the minimum number of members required in the cluster for the lock to remain functional.
splitBrainProtectionName - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddListConfigCodec.RequestParameters
name of an existing configured split brain protection to be used to determine the minimum number of members required in the cluster for the lock to remain functional.
splitBrainProtectionName - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
name of an existing configured split brain protection to be used to determine the minimum number of members required in the cluster for the map to remain functional.
splitBrainProtectionName - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMultiMapConfigCodec.RequestParameters
name of an existing configured split brain protection to be used to determine the minimum number of members required in the cluster for the lock to remain functional.
splitBrainProtectionName - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddPNCounterConfigCodec.RequestParameters
name of an existing configured split brain protection to be used to determine the minimum number of members required in the cluster for the lock to remain functional.
splitBrainProtectionName - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddQueueConfigCodec.RequestParameters
name of an existing configured split brain protection to be used to determine the minimum number of members required in the cluster for the queue to remain functional.
splitBrainProtectionName - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReplicatedMapConfigCodec.RequestParameters
name of an existing configured split brain protection to be used to determine the minimum number of members required in the cluster for the lock to remain functional.
splitBrainProtectionName - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddRingbufferConfigCodec.RequestParameters
name of an existing configured split brain protection to be used to determine the minimum number of members required in the cluster for the lock to remain functional.
splitBrainProtectionName - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddScheduledExecutorConfigCodec.RequestParameters
name of an existing configured split brain protection to be used to determine the minimum number of members required in the cluster for the lock to remain functional.
splitBrainProtectionName - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddSetConfigCodec.RequestParameters
name of an existing configured split brain protection to be used to determine the minimum number of members required in the cluster for the lock to remain functional.
splitBrainProtectionName - Variable in class com.hazelcast.config.AbstractBasicConfig
 
splitBrainProtectionName - Variable in class com.hazelcast.map.impl.MapContainer
 
SplitBrainProtectionOn - Enum in com.hazelcast.splitbrainprotection
Represents a cluster split brain protection type
SplitBrainProtectionService - Interface in com.hazelcast.splitbrainprotection
Split brain protection service can be used to trigger cluster split brain protections at any time.
SplitBrainProtectionServiceImpl - Class in com.hazelcast.splitbrainprotection.impl
Service containing logic for cluster split brain protection.
SplitBrainProtectionServiceImpl(NodeEngineImpl) - Constructor for class com.hazelcast.splitbrainprotection.impl.SplitBrainProtectionServiceImpl
 
splitByComma(String, boolean) - Static method in class com.hazelcast.internal.util.StringUtil
Splits String value with comma "," used as a separator.
SpringAware - Annotation Type in com.hazelcast.spring.context
Annotates a class for injection of Spring dependencies.
SpringHazelcastCachingProvider - Class in com.hazelcast.spring.cache
Spring utility class for connecting HazelcastCachingProvider interface and Hazelcast instance.
SpringManagedContext - Class in com.hazelcast.spring.context
ManagedContext implementation for Hazelcast.
SpringManagedContext() - Constructor for class com.hazelcast.spring.context.SpringManagedContext
 
SpringXmlBuilder(ParserContext, BeanDefinitionBuilder) - Constructor for class com.hazelcast.spring.HazelcastClientBeanDefinitionParser.SpringXmlBuilder
 
SpringXmlBuilderHelper() - Constructor for class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
sql - Variable in class com.hazelcast.config.PredicateConfig
 
sql(String) - Static method in class com.hazelcast.query.Predicates
Creates a SQL predicate that will pass items that match the given SQL 'where' expression.
SQL_DATE_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
SQL_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
SQL_TIMESTAMP_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
SqlPredicate - Class in com.hazelcast.query.impl.predicates
This class contains methods related to conversion of 'sql' query to predicate.
SqlPredicate(String) - Constructor for class com.hazelcast.query.impl.predicates.SqlPredicate
 
SqlPredicate() - Constructor for class com.hazelcast.query.impl.predicates.SqlPredicate
 
src - Variable in class com.hazelcast.internal.networking.ChannelHandler
 
src() - Method in class com.hazelcast.internal.networking.ChannelHandler
Gets the source of this ChannelHandler.
src(S) - Method in class com.hazelcast.internal.networking.ChannelHandler
Sets the source of this ChannelHandler.
ss - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
ss - Variable in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
 
ss - Variable in class com.hazelcast.query.impl.AbstractIndex
 
sslConfig - Variable in class com.hazelcast.config.EndpointConfig
 
SSLConfig - Class in com.hazelcast.config
SSL configuration.
SSLConfig() - Constructor for class com.hazelcast.config.SSLConfig
 
SSLConfig(SSLConfig) - Constructor for class com.hazelcast.config.SSLConfig
 
SSLContextFactory - Interface in com.hazelcast.nio.ssl
Factory class for creating SSLContext
STACK_OVERFLOW_ERROR - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
stackTrace - Variable in class com.hazelcast.internal.management.dto.SlowOperationDTO
 
StackTraceElementCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
STALE_APPEND_REQUEST_EXCEPTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
STALE_JOIN_PREVENTION_DURATION_PROP - Static variable in class com.hazelcast.internal.cluster.impl.ClusterJoinManager
 
STALE_SEQUENCE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
STALE_TASK - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
STALE_TASK_ID - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
StaleAppendRequestException - Exception in com.hazelcast.cp.exception
A CPSubsystemException which is thrown when a Raft leader node appends an entry to its local Raft log, but demotes to the follower role before learning the commit status of the entry.
StaleAppendRequestException(RaftEndpoint) - Constructor for exception com.hazelcast.cp.exception.StaleAppendRequestException
 
StaleReadDetector - Interface in com.hazelcast.internal.nearcache.impl.invalidation
Used to detect staleness of Near Cache data.
staleReadDetector - Variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
StaleReadDetectorImpl - Class in com.hazelcast.internal.nearcache.impl.invalidation
Default implementation of StaleReadDetector.
StaleSequenceException - Exception in com.hazelcast.ringbuffer
An RuntimeException that is thrown when accessing an item in the Ringbuffer using a sequence that is smaller than the current head sequence and that the ringbuffer store is disabled.
StaleSequenceException(String, long) - Constructor for exception com.hazelcast.ringbuffer.StaleSequenceException
Creates a StaleSequenceException with the given message.
StaleTaskException - Exception in com.hazelcast.scheduledexecutor
Exception thrown by the IScheduledFuture during any operation on a stale (=previously destroyed) task.
StaleTaskException(String) - Constructor for exception com.hazelcast.scheduledexecutor.StaleTaskException
 
StaleTaskIdException - Exception in com.hazelcast.durableexecutor
An RuntimeException that is thrown when retrieving the result of a task via DurableExecutorService if the result of the task is overwritten.
StaleTaskIdException(String) - Constructor for exception com.hazelcast.durableexecutor.StaleTaskIdException
 
StandardLoggerFactory - Class in com.hazelcast.logging
 
StandardLoggerFactory() - Constructor for class com.hazelcast.logging.StandardLoggerFactory
 
StandardMemoryAccessor - Class in com.hazelcast.internal.memory.impl
Standard MemoryAccessor implementations that directly uses Unsafe for accessing to memory.
start - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
start(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
 
start() - Method in class com.hazelcast.client.impl.ClientHeartbeatMonitor
 
start() - Method in class com.hazelcast.client.impl.ClientLifecycleMonitor
 
start() - Method in class com.hazelcast.client.impl.clientside.CandidateClusterContext
 
start() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientInstanceImpl
 
start() - Method in class com.hazelcast.client.impl.clientside.LifecycleServiceImpl
 
start() - Method in class com.hazelcast.client.impl.connection.ClientConnectionStrategy
Starts the ClientConnectionStrategy; this will trigger connecting to the cluster.
start() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
start() - Method in class com.hazelcast.client.impl.connection.nio.ClientICMPManager
 
start() - Method in class com.hazelcast.client.impl.connection.nio.DefaultClientConnectionStrategy
 
start() - Method in class com.hazelcast.client.impl.connection.nio.HeartbeatManager
 
start(Xid, int) - Method in class com.hazelcast.client.impl.proxy.txn.xa.XAResourceProxy
 
start() - Method in class com.hazelcast.client.impl.spi.impl.AbstractClientInvocationService
 
start() - Method in class com.hazelcast.client.impl.spi.impl.ClientClusterServiceImpl
 
start() - Method in class com.hazelcast.client.impl.spi.impl.ClientPartitionServiceImpl
 
start() - Method in class com.hazelcast.client.impl.spi.impl.ClientResponseHandlerSupplier
 
start() - Method in class com.hazelcast.client.impl.spi.impl.ClientUserCodeDeploymentService
 
start() - Method in class com.hazelcast.client.impl.spi.impl.listener.AbstractClientListenerService
 
start() - Method in class com.hazelcast.client.impl.spi.impl.listener.SmartClientListenerService
 
start() - Method in class com.hazelcast.client.impl.statistics.Statistics
Registers all client statistics and schedules periodic collection of stats.
start() - Method in class com.hazelcast.console.ConsoleApp
 
start() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Starts the periodic tasks, such as voting, leader failure-detection, snapshot handling.
start() - Method in class com.hazelcast.internal.diagnostics.Diagnostics
 
start() - Method in class com.hazelcast.internal.diagnostics.HealthMonitor
 
start() - Method in interface com.hazelcast.internal.networking.Channel
Starts the Channel.
start() - Method in class com.hazelcast.internal.networking.nio.iobalancer.IOBalancer
 
start() - Method in class com.hazelcast.internal.networking.nio.NioChannel
 
start() - Method in interface com.hazelcast.internal.nio.NetworkingService
Starts the service, initializes its endpoints, starts threads, etc.
start() - Method in class com.hazelcast.internal.nio.tcp.TcpIpAcceptor
 
start() - Method in class com.hazelcast.internal.nio.tcp.TcpIpNetworkingService
 
start() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
 
start() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreManager
 
start() - Method in class com.hazelcast.map.impl.mapstore.writebehind.StoreWorker
 
start() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindManager
 
start() - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughManager
 
start(BundleContext) - Method in class com.hazelcast.osgi.impl.Activator
 
start() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
 
start() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
The start method is used to initialize internal state and perform any kind of startup procedure like multicast socket creation.
start() - Method in class com.hazelcast.spi.discovery.impl.DefaultDiscoveryService
 
start() - Method in class com.hazelcast.spi.discovery.impl.PredefinedDiscoveryService
 
start() - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryService
The start method is called on system startup to implement simple lifecycle management.
start() - Method in class com.hazelcast.spi.discovery.multicast.MulticastDiscoveryStrategy
 
start() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
start() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
start() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
Starts this OperationExecutor.
start() - Method in class com.hazelcast.spi.impl.operationexecutor.slowoperationdetector.SlowOperationDetector
 
start() - Method in class com.hazelcast.spi.impl.operationservice.impl.InboundResponseHandlerSupplier
 
start() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationMonitor
 
start() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
start() - Method in class com.hazelcast.spi.impl.operationservice.Offload
Starts the actual offloading.
start() - Method in class com.hazelcast.spi.impl.servicemanager.impl.ServiceManagerImpl
 
start() - Method in class com.hazelcast.splitbrainprotection.impl.SplitBrainProtectionServiceImpl
 
start(Xid, int) - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
 
startArray() - Method in class com.hazelcast.internal.json.JsonHandler
Indicates the beginning of an array in the JSON input.
startArrayValue(A) - Method in class com.hazelcast.internal.json.JsonHandler
Indicates the beginning of an array element in the JSON input.
startBoolean() - Method in class com.hazelcast.internal.json.JsonHandler
Indicates the beginning of a boolean literal (true or false) in the JSON input.
startClusterMerge(Address, int) - Method in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
startedAt - Variable in class com.hazelcast.internal.management.dto.SlowOperationInvocationDTO
 
startExecution(long) - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
 
startInitialLoad(MapStoreContext, int) - Method in class com.hazelcast.map.impl.MapKeyLoader
Triggers key loading on the map key loader with the Role#SENDER role.
startLoading(MapStoreContext, boolean) - Method in class com.hazelcast.map.impl.MapKeyLoader
Triggers key and value loading if there is no ongoing or completed key loading task, otherwise does nothing.
startLoading() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
startLoading() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Starts the map loader if there is a configured and enabled MapLoader and the key loading has not already been started.
startNetworking() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
startNull() - Method in class com.hazelcast.internal.json.JsonHandler
Indicates the beginning of a null literal in the JSON input.
startNumber() - Method in class com.hazelcast.internal.json.JsonHandler
Indicates the beginning of a number in the JSON input.
startObject() - Method in class com.hazelcast.internal.json.JsonHandler
Indicates the beginning of an object in the JSON input.
startObjectName(O) - Method in class com.hazelcast.internal.json.JsonHandler
Indicates the beginning of the name of an object member in the JSON input.
startObjectValue(O, String) - Method in class com.hazelcast.internal.json.JsonHandler
Indicates the beginning of the name of an object member in the JSON input.
startPending() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
 
startProcessing() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
startSection(String) - Method in interface com.hazelcast.internal.diagnostics.DiagnosticsLogWriter
 
startSection(String) - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
startSection(String, long) - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
startSequence - Variable in class com.hazelcast.client.impl.protocol.codec.CacheEventJournalReadCodec.RequestParameters
the startSequence of the first item to read
startSequence - Variable in class com.hazelcast.client.impl.protocol.codec.MapEventJournalReadCodec.RequestParameters
the startSequence of the first item to read
startSequence - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferReadManyCodec.RequestParameters
the startSequence of the first item to read
startSequence - Variable in class com.hazelcast.internal.journal.EventJournalReadOperation
 
StartServer - Class in com.hazelcast.core.server
Starts a Hazelcast server.
startString() - Method in class com.hazelcast.internal.json.JsonHandler
Indicates the beginning of a string in the JSON input.
startTimeNanos - Variable in class com.hazelcast.client.impl.protocol.task.map.AbstractMapPutMessageTask
 
startTimeNanos - Variable in class com.hazelcast.client.impl.protocol.task.map.AbstractMapSetMessageTask
 
startTimeNanos - Variable in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
 
STAT_NOT_AVAILABLE - Static variable in interface com.hazelcast.monitor.LocalInstanceStats
Default value for unavailable statistics.
state - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
state() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
state - Variable in class com.hazelcast.scheduledexecutor.impl.operations.SyncStateOperation
 
state - Variable in class com.hazelcast.spi.impl.AbstractInvocationFuture
This field contains the state of the future.
stateChanged(LifecycleEvent) - Method in class com.hazelcast.client.util.ClientStateListener
 
stateChanged(LifecycleEvent) - Method in interface com.hazelcast.core.LifecycleListener
Called when instance's state changes.
stateChanged(LifecycleEvent) - Method in class com.hazelcast.internal.eviction.ExpirationManager
 
StatefulTask<K,V> - Interface in com.hazelcast.scheduledexecutor
An interface to provide means for saving & loading state for Runnable and Callable tasks scheduled with an IScheduledExecutorService.
StateMachine<T extends Enum<T>> - Class in com.hazelcast.internal.util
Simple state machine using an Enum as possible states.
StateMachine(T) - Constructor for class com.hazelcast.internal.util.StateMachine
 
stateStore() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns the state store that persists changes on this Raft state
stateToString() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateManager
 
StaticCredentialsFactory - Class in com.hazelcast.config.security
The credentials factory implementation which just takes credentials in a constructor and provides it for every StaticCredentialsFactory.newCredentials() call.
StaticCredentialsFactory(Credentials) - Constructor for class com.hazelcast.config.security.StaticCredentialsFactory
 
StaticLB - Class in com.hazelcast.client.util
The StaticLB is a LoadBalancer that always returns the same member.
StaticLB(Member) - Constructor for class com.hazelcast.client.util.StaticLB
 
StaticMetricsProvider - Interface in com.hazelcast.internal.metrics
To be implemented by an object that can provide metrics (so has a bunch of probes).
statistics - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
statistics - Variable in class com.hazelcast.cache.impl.AbstractCacheService
Map from full prefixed cache name to CacheStatisticsImpl
Statistics - Class in com.hazelcast.client.impl.statistics
This class is the main entry point for collecting and sending the client statistics to the cluster.
Statistics(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.impl.statistics.Statistics
 
StatisticsAwareMetricsSet - Class in com.hazelcast.internal.metrics.metricsets
A MetricsSet that captures all the StatisticsAwareService services.
StatisticsAwareService<T extends LocalInstanceStats> - Interface in com.hazelcast.internal.services
A service implementing this interface provides local instance statistics.
statisticsAwareService - Variable in class com.hazelcast.map.impl.MapService
 
statisticsEnabled - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
true to enable gathering of statistics, otherwise false
statisticsEnabled - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddExecutorConfigCodec.RequestParameters
true to enable gathering of statistics, otherwise false
statisticsEnabled - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddFlakeIdGeneratorConfigCodec.RequestParameters
true to enable gathering of statistics, otherwise false
statisticsEnabled - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddListConfigCodec.RequestParameters
true to enable gathering of statistics on the list, otherwise false
statisticsEnabled - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
true to enable gathering of statistics, otherwise false
statisticsEnabled - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMultiMapConfigCodec.RequestParameters
set to true to enable statistics on this multimap configuration
statisticsEnabled - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddPNCounterConfigCodec.RequestParameters
set to true to enable statistics on this multimap configuration
statisticsEnabled - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddQueueConfigCodec.RequestParameters
true to enable gathering of statistics, otherwise false
statisticsEnabled - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReliableTopicConfigCodec.RequestParameters
true to enable gathering of statistics, otherwise false
statisticsEnabled - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReplicatedMapConfigCodec.RequestParameters
true to enable gathering of statistics, otherwise false
statisticsEnabled - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddSetConfigCodec.RequestParameters
true to enable gathering of statistics on the list, otherwise false
statisticsEnabled - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddTopicConfigCodec.RequestParameters
true to enable gathering of statistics, otherwise false
stats - Variable in class com.hazelcast.client.impl.protocol.codec.ClientStatisticsCodec.RequestParameters
The key=value pairs separated by the ',' character
Stats - Class in com.hazelcast.internal.ascii.memcache
 
Stats() - Constructor for class com.hazelcast.internal.ascii.memcache.Stats
 
stats - Variable in class com.hazelcast.scheduledexecutor.impl.operations.SyncStateOperation
 
StatsCommand - Class in com.hazelcast.internal.ascii.memcache
 
StatsCommand() - Constructor for class com.hazelcast.internal.ascii.memcache.StatsCommand
 
StatsCommandProcessor - Class in com.hazelcast.internal.ascii.memcache
 
StatsCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.memcache.StatsCommandProcessor
 
statsEnabled(boolean) - Method in class com.hazelcast.query.impl.Indexes.Builder
 
StatsSupplier<T> - Interface in com.hazelcast.internal.jmx.suppliers
Interface used in MBeans for retrieving the Local Stats
status - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec.ResponseParameters
TODO DOC
status - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec.ResponseParameters
TODO DOC
status() - Method in interface com.hazelcast.cp.CPGroup
Returns status of the CP group
status() - Method in class com.hazelcast.cp.internal.CPGroupInfo
 
status() - Method in class com.hazelcast.cp.internal.CPGroupSummary
 
status() - Method in class com.hazelcast.cp.internal.datastructures.lock.AcquireResult
 
status() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.AcquireResult
 
stepDownRaftNode(CPGroupId) - Method in class com.hazelcast.cp.internal.RaftService
 
stop() - Method in class com.hazelcast.client.console.ClientConsoleApp
 
stop() - Method in class com.hazelcast.console.ConsoleApp
 
stop() - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
stop() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
stop() - Method in class com.hazelcast.internal.cluster.impl.MulticastService
 
stop() - Method in class com.hazelcast.internal.diagnostics.HealthMonitor
 
stop() - Method in class com.hazelcast.internal.networking.nio.iobalancer.IOBalancer
 
stop() - Method in interface com.hazelcast.internal.nio.NetworkingService
Stops the service, releases its resources, stops threads, etc.
stop() - Method in class com.hazelcast.internal.nio.tcp.TcpIpNetworkingService
 
stop() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
 
stop() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreManager
 
stop() - Method in class com.hazelcast.map.impl.mapstore.writebehind.StoreWorker
 
stop() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindManager
 
stop() - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughManager
 
stop(BundleContext) - Method in class com.hazelcast.osgi.impl.Activator
 
stop() - Method in class com.hazelcast.spi.discovery.multicast.impl.MulticastDiscoverySender
 
stop(String, String) - Method in interface com.hazelcast.wan.impl.WanReplicationService
Stops WAN replication for the given wanReplicationName and wanPublisherId on this hazelcast instance.
stop(String, String) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
 
stop() - Method in interface com.hazelcast.wan.WanReplicationPublisher
Calls to this method will stop WAN replication.
stopNetworking() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnectionManagerImpl
 
Storage<K,R> - Interface in com.hazelcast.map.impl.recordstore
Represents actual storage layer behind a RecordStore.
StorageImpl<R extends Record> - Class in com.hazelcast.map.impl.recordstore
Default implementation of Storage layer used by a RecordStore
storageRef - Variable in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
 
StorageSCHM<R extends Record> - Class in com.hazelcast.map.impl.recordstore
An extended SampleableConcurrentHashMap with IMap specifics.
StorageSCHM(SerializationService) - Constructor for class com.hazelcast.map.impl.recordstore.StorageSCHM
 
store(Long, T) - Method in class com.hazelcast.collection.impl.queue.LatencyTrackingQueueStore
 
store(Long, Data) - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
 
store(Long, T) - Method in interface com.hazelcast.collection.QueueStore
Stores the key-value pair.
store(String, ClassSource) - Static method in class com.hazelcast.internal.usercodedeployment.impl.ThreadLocalClassCache
 
store(K, V) - Method in class com.hazelcast.map.impl.LatencyTrackingMapStore
 
store(Object, Object) - Method in class com.hazelcast.map.impl.MapStoreWrapper
 
store(K, V) - Method in interface com.hazelcast.map.MapStore
Stores the key-value pair.
store(K, V) - Method in class com.hazelcast.map.MapStoreAdapter
Stores the key-value pair.
store(long, Data) - Method in class com.hazelcast.ringbuffer.impl.RingbufferStoreWrapper
 
store(long, T) - Method in interface com.hazelcast.ringbuffer.RingbufferStore
Stores one item with it's corresponding sequence.
StoreAdapter<R> - Interface in com.hazelcast.map.impl
Adapter of arbitrary store.
storeAll(Map<Long, T>) - Method in class com.hazelcast.collection.impl.queue.LatencyTrackingQueueStore
 
storeAll(Map<Long, Data>) - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
 
storeAll(Map<Long, T>) - Method in interface com.hazelcast.collection.QueueStore
Stores multiple entries.
storeAll(Map<K, V>) - Method in class com.hazelcast.map.impl.LatencyTrackingMapStore
 
storeAll(Map) - Method in class com.hazelcast.map.impl.MapStoreWrapper
 
storeAll(Map<K, V>) - Method in interface com.hazelcast.map.MapStore
Stores multiple entries.
storeAll(Map<K, V>) - Method in class com.hazelcast.map.MapStoreAdapter
Stores multiple entries.
storeAll(long, Data[]) - Method in class com.hazelcast.ringbuffer.impl.RingbufferStoreWrapper
 
storeAll(long, T[]) - Method in interface com.hazelcast.ringbuffer.RingbufferStore
Stores multiple items.
STORED - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
 
StoreEvent<E> - Class in com.hazelcast.map.impl.mapstore.writebehind
For internal usage only.
storeIterator(CachePartitionSegment) - Method in class com.hazelcast.cache.impl.eviction.CacheClearExpiredRecordsTask
 
storeIterator(T) - Method in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
storeIterator(PartitionContainer) - Method in class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
 
storeIterator(int) - Method in class com.hazelcast.spi.impl.merge.AbstractSplitBrainHandlerService
Returns an Iterator over all Store instances in the given partition.
storeKeys() - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
storeKeys(Iterator<K>) - Method in class com.hazelcast.internal.nearcache.impl.preloader.NearCachePreloader
Stores the Near Cache keys from the supplied iterator.
storeKeys() - Method in class com.hazelcast.internal.nearcache.impl.store.BaseHeapNearCacheRecordStore
 
storeKeys() - Method in interface com.hazelcast.internal.nearcache.NearCache
Stores the keys of the Near Cache.
storeKeys() - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
Persists the key set of the Near Cache.
storeLastCleanupTime() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
 
StoreLatencyPlugin - Class in com.hazelcast.internal.diagnostics
A DiagnosticsPlugin that helps to detect if there are any performance issues with Stores/Loaders like e.g.
StoreLatencyPlugin(NodeEngineImpl) - Constructor for class com.hazelcast.internal.diagnostics.StoreLatencyPlugin
 
StoreLatencyPlugin(ILogger, HazelcastProperties) - Constructor for class com.hazelcast.internal.diagnostics.StoreLatencyPlugin
 
StoreLatencyPlugin.LatencyProbe - Interface in com.hazelcast.internal.diagnostics
 
storeRecordsToReplicate(ICacheRecordStore) - Method in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
 
storesByMapName - Variable in class com.hazelcast.map.impl.operation.MapReplicationStateHolder
 
storeSequence(long) - Method in class com.hazelcast.topic.impl.reliable.ReliableMessageListenerAdapter
 
storeSequence(long) - Method in interface com.hazelcast.topic.ReliableMessageListener
Informs the ReliableMessageListener that it should store the sequence.
StoreWorker - Class in com.hazelcast.map.impl.mapstore.writebehind
When write-behind is enabled the work is offloaded to another thread than partition-operation-thread.
StoreWorker(MapStoreContext, WriteBehindProcessor) - Constructor for class com.hazelcast.map.impl.mapstore.writebehind.StoreWorker
 
stream() - Method in class com.hazelcast.internal.metrics.managementcenter.ConcurrentArrayRingbuffer.RingbufferSlice
 
StreamSerializer<T> - Interface in com.hazelcast.nio.serialization
A base class for custom serialization.
STRING_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
StringAndPartitionAwarePartitioningStrategy - Class in com.hazelcast.partition.strategy
 
StringArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.StringArraySerializer
 
StringCodec - Class in com.hazelcast.client.impl.protocol.codec.builtin
 
StringNavigableJsonAdapter - Class in com.hazelcast.internal.serialization.impl
 
StringNavigableJsonAdapter(String, int) - Constructor for class com.hazelcast.internal.serialization.impl.StringNavigableJsonAdapter
 
StringPartitioningStrategy - Class in com.hazelcast.partition.strategy
 
StringPartitioningStrategy() - Constructor for class com.hazelcast.partition.strategy.StringPartitioningStrategy
 
StringSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.StringSerializer
 
stringToBytes(String) - Static method in class com.hazelcast.internal.util.StringUtil
Creates a byte array from a string.
StringUtil - Class in com.hazelcast.internal.util
Utility class for Strings.
stripBaseTime(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
 
StripedExecutor - Class in com.hazelcast.internal.util.executor
The StripedExecutor internally uses a stripe of queues and each queue has its own private worker-thread.
StripedExecutor(ILogger, String, int, int) - Constructor for class com.hazelcast.internal.util.executor.StripedExecutor
 
StripedExecutor(ILogger, String, int, int, boolean) - Constructor for class com.hazelcast.internal.util.executor.StripedExecutor
 
StripedRunnable - Interface in com.hazelcast.internal.util.executor
Striped Runnable is used in StripedExecutor.
StubAuthenticationException - Exception in com.hazelcast.client.impl
This is equivalent of AuthenticationException from client side.
StubAuthenticationException(String) - Constructor for exception com.hazelcast.client.impl.StubAuthenticationException
 
sub(int, int) - Method in class com.hazelcast.collection.impl.list.ListContainer
 
subList(int, int) - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
subList(int, int) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
 
subList(int, int) - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
 
submit(Callable<T>) - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
submit(Runnable, T) - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
submit(Runnable) - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
submit(Callable<T>, MemberSelector) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submit(Runnable, MemberSelector, ExecutionCallback) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submit(Callable<T>, MemberSelector, ExecutionCallback<T>) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submit(Runnable) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submit(Runnable, T) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submit(Callable<T>) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submit(Runnable, ExecutionCallback<T>) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submit(Callable<T>, ExecutionCallback<T>) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submit(Callable<T>, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to a randomly selected member and returns a Future representing that task.
submit(Runnable, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to a random member.
submit(Runnable, MemberSelector, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to randomly selected members.
submit(Callable<T>, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to a random member.
submit(Callable<T>, MemberSelector, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits task to a randomly selected member.
submit(Runnable) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Submits the given task for execution.
submit(Callable<T>) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Submits a value-returning task for execution and returns a Future representing the pending results of the task.
submit(Runnable, T) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Submits a Runnable task for execution and returns a Future representing that task.
submit(Runnable) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Submits a Runnable task for execution and returns a Future representing that task.
submit(Runnable, T) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
submit(Runnable) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
submit(Callable<T>) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
submit(Callable<T>, MemberSelector) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submit(Runnable, MemberSelector, ExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submit(Callable<T>, MemberSelector, ExecutionCallback<T>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submit(Runnable) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submit(Runnable, T) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submit(Callable<T>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submit(Runnable, ExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submit(Callable<T>, ExecutionCallback<T>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submit(Queue<E>, E) - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Blocks until successfully inserting the given item to the given queue.
submit(E) - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyorSingleQueue
Submits an item to the queue.
submit(Callable<T>) - Method in class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
submit(Runnable, T) - Method in class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
submit(Runnable) - Method in class com.hazelcast.internal.util.executor.CachedExecutorServiceDelegate
 
submit(String, Runnable) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
submit(String, Callable<T>) - Method in interface com.hazelcast.spi.impl.executionservice.ExecutionService
 
submit(String, Runnable) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
submit(String, Callable<T>) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
SUBMIT_IDLER - Static variable in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Idling strategy used by the submit() methods.
SUBMIT_MAX_PARK_MICROS - Static variable in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
Max park microseconds while waiting to submit to the work queue.
SUBMIT_SPIN_COUNT - Static variable in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
How many times to busy-spin while waiting to submit to the work queue.
SUBMIT_YIELD_COUNT - Static variable in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
How many times to yield while waiting to submit to the work queue.
submitterGoneItem() - Method in class com.hazelcast.internal.util.concurrent.ConcurrentConveyor
 
submitToAllMembers(Callable<T>) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submitToAllMembers(Runnable, MultiExecutionCallback) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submitToAllMembers(Callable<T>, MultiExecutionCallback) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submitToAllMembers(Callable<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits task to all cluster members and returns a map of Member-Future pairs representing pending completion of the task on each member.
submitToAllMembers(Runnable, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
Submits task to all the cluster members.
submitToAllMembers(Callable<T>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
Submits task to all the cluster members.
submitToAllMembers(Callable<T>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submitToAllMembers(Runnable, MultiExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submitToAllMembers(Callable<T>, MultiExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submitToKey(K, EntryProcessor<K, V, R>, ExecutionCallback<? super R>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
submitToKey(K, EntryProcessor<K, V, R>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
submitToKey(K, EntryProcessor<K, V, R>, ExecutionCallback<? super R>) - Method in interface com.hazelcast.map.IMap
Applies the user defined EntryProcessor to the entry mapped by the key with specified ExecutionCallback to listen event status and returns immediately.
submitToKey(K, EntryProcessor<K, V, R>) - Method in interface com.hazelcast.map.IMap
Applies the user defined EntryProcessor to the entry mapped by the key.
submitToKey(K, EntryProcessor<K, V, R>, ExecutionCallback<? super R>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
submitToKey(K, EntryProcessor<K, V, R>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
submitToKeyInternal(Object, EntryProcessor<K, V, R>, ExecutionCallback<? super R>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
submitToKeyInternal(Object, EntryProcessor<K, V, R>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
submitToKeyInternal(Object, EntryProcessor<K, V, R>) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
submitToKeyInternal(Object, EntryProcessor<K, V, R>, ExecutionCallback<? super R>) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
submitToKeyOwner(Callable<T>, Object) - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
submitToKeyOwner(Runnable, Object) - Method in class com.hazelcast.client.impl.proxy.ClientDurableExecutorServiceProxy
 
submitToKeyOwner(Callable<T>, Object) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submitToKeyOwner(Runnable, Object, ExecutionCallback) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submitToKeyOwner(Callable<T>, Object, ExecutionCallback<T>) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submitToKeyOwner(Callable<T>, Object) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the owner of the specified key and returns a Future representing that task.
submitToKeyOwner(Runnable, Object, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the owner of the specified key.
submitToKeyOwner(Callable<T>, Object, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits task to the owner of the specified key.
submitToKeyOwner(Callable<T>, Object) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Submits a task to the owner of the specified key and returns a Future representing that task.
submitToKeyOwner(Runnable, Object) - Method in interface com.hazelcast.durableexecutor.DurableExecutorService
Submits a task to the owner of the specified key and returns a Future representing that task.
submitToKeyOwner(Callable<T>, Object) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
submitToKeyOwner(Runnable, Object) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
submitToKeyOwner(Callable<T>, Object) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submitToKeyOwner(Runnable, Object, ExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submitToKeyOwner(Callable<T>, Object, ExecutionCallback<T>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submitToKeys(Set<K>, EntryProcessor<K, V, R>) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
submitToKeys(Set<K>, EntryProcessor<K, V, R>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
submitToKeysInternal(Set<K>, Set<Data>, EntryProcessor<K, V, R>) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
submitToMember(Callable<T>, Member) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submitToMember(Runnable, Member, ExecutionCallback) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submitToMember(Callable<T>, Member, ExecutionCallback<T>) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submitToMember(Callable<T>, Member) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the specified member and returns a Future representing that task.
submitToMember(Runnable, Member, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the specified member.
submitToMember(Callable<T>, Member, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the specified member.
submitToMember(Callable<T>, Member) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submitToMember(Runnable, Member, ExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submitToMember(Callable<T>, Member, ExecutionCallback<T>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submitToMembers(Callable<T>, Collection<Member>) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submitToMembers(Callable<T>, MemberSelector) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submitToMembers(Runnable, Collection<Member>, MultiExecutionCallback) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submitToMembers(Callable<T>, Collection<Member>, MultiExecutionCallback) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submitToMembers(Runnable, MemberSelector, MultiExecutionCallback) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submitToMembers(Callable<T>, MemberSelector, MultiExecutionCallback) - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
submitToMembers(Callable<T>, Collection<Member>) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to given members and returns map of Member-Future pairs representing pending completion of the task on each member
submitToMembers(Callable<T>, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to selected members and returns a map of Member-Future pairs representing pending completion of the task on each member.
submitToMembers(Runnable, Collection<Member>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the specified members.
submitToMembers(Runnable, MemberSelector, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
Submits task to the selected members.
submitToMembers(Callable<T>, Collection<Member>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
Submits a task to the specified members.
submitToMembers(Callable<T>, MemberSelector, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
Submits task to the selected members.
submitToMembers(Callable<T>, MemberSelector) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submitToMembers(Runnable, MemberSelector, MultiExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submitToMembers(Callable<T>, MemberSelector, MultiExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submitToMembers(Callable<T>, Collection<Member>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submitToMembers(Runnable, Collection<Member>, MultiExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
submitToMembers(Callable<T>, Collection<Member>, MultiExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
SubscriberAccumulator - Class in com.hazelcast.map.impl.querycache.subscriber
If all incoming events are in the correct sequence order, this accumulator applies those events to QueryCache.
SubscriberAccumulator(QueryCacheContext, AccumulatorInfo) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.SubscriberAccumulator
 
SubscriberAccumulatorFactory - Class in com.hazelcast.map.impl.querycache.subscriber
Subscriber part implementation of AccumulatorFactory.
SubscriberAccumulatorFactory(QueryCacheContext) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.SubscriberAccumulatorFactory
 
subscriberContext - Variable in class com.hazelcast.map.impl.querycache.subscriber.AbstractQueryCacheEndToEndConstructor
 
SubscriberContext - Interface in com.hazelcast.map.impl.querycache.subscriber
Context contract for subscriber side of a QueryCache implementation.
SubscriberContextSupport - Interface in com.hazelcast.map.impl.querycache.subscriber
Contains various helpers for SubscriberContext.
SubscriberListener - Class in com.hazelcast.map.impl.querycache.subscriber
Subscriber side listener per QueryCache which listens events sent by publisher-sides.
SubscriberListener(QueryCacheContext, AccumulatorInfo) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.SubscriberListener
 
SubscriberRegistry - Class in com.hazelcast.map.impl.querycache.subscriber
All registered subscriber side accumulators for an IMap can be reached from this registry class.
SubscriberRegistry(QueryCacheContext, String) - Constructor for class com.hazelcast.map.impl.querycache.subscriber.SubscriberRegistry
 
SubscriberSequencerProvider - Interface in com.hazelcast.map.impl.querycache.event.sequence
Provides sequences for subscriber side.
subscribeToEventJournal(int) - Method in class com.hazelcast.cache.impl.CacheProxy
 
subscribeToEventJournal(int) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
subscribeToEventJournal(int) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
subscribeToEventJournal(int) - Method in interface com.hazelcast.internal.journal.EventJournalReader
Subscribe to the event journal for this reader and a specific partition ID.
subscribeToEventJournal(int) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
subtractAndGet(long) - Method in class com.hazelcast.client.impl.proxy.ClientPNCounterProxy
 
subtractAndGet(long) - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Subtracts the given value from the current value.
subtractAndGet(long, VectorClock) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterImpl
Subtracts the given value from the current value.
subtractAndGet(long) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterProxy
 
subtraction(String[], String[]) - Static method in class com.hazelcast.internal.util.StringUtil
Returns subtraction between given String arrays.
SUCCESS - Static variable in class com.hazelcast.internal.management.request.WanCheckConsistencyRequest
Result message when WanCheckConsistencyRequest is invoked successfully
SUCCESS_RESULT - Static variable in class com.hazelcast.internal.management.request.ForceStartNodeRequest
Result sent within response when force start is triggered successfully
SUCCESS_RESULT - Static variable in class com.hazelcast.internal.management.request.TriggerPartialStartRequest
Result sent within response when partial start is triggered successfully
successful - Variable in class com.hazelcast.map.impl.operation.PutIfAbsentOperation
 
successful - Variable in class com.hazelcast.map.impl.operation.RemoveOperation
 
SuffixModifierUtils - Class in com.hazelcast.query.impl.getters
Convenient utilities to parse attribute suffix modifiers from attributes.
sumHash(int, int) - Static method in class com.hazelcast.wan.impl.merkletree.MerkleTreeUtil
Sums the hash of the left and the right children
SupplierEx<T> - Interface in com.hazelcast.internal.util.function
Serializable variant of java.util.function.Supplier which declares checked exception.
supplierFor(Class<T>) - Static method in class com.hazelcast.internal.dynamicconfig.search.ConfigSearch
Factory method for providing ConfigSupplier instances for the given config class
supportedProtocol - Variable in class com.hazelcast.internal.nio.tcp.SingleProtocolDecoder
 
supports(String) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Checks whether the given XML tag is supported.
suspectAddressIfNotConnected(Address) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
suspectMember(Member, String, boolean) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
suspend(Transaction) - Method in class com.hazelcast.transaction.impl.SuspendedTransaction
 
SuspendedTransaction - Class in com.hazelcast.transaction.impl
Base class for suspended Transaction implementations.
SuspendedTransaction(Transaction) - Constructor for class com.hazelcast.transaction.impl.SuspendedTransaction
 
suspendTransaction() - Method in class com.hazelcast.client.impl.proxy.txn.TransactionContextProxy
 
suspendTransaction() - Method in class com.hazelcast.client.impl.proxy.txn.xa.XATransactionContextProxy
 
suspendTransaction() - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
 
suspendTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Suspend current transaction.
suspicionLevel(Member, long) - Method in interface com.hazelcast.internal.cluster.fd.ClusterFailureDetector
Returns suspicion level about a given member.
suspicionLevel(Member, long) - Method in class com.hazelcast.internal.cluster.fd.DeadlineClusterFailureDetector
 
suspicionLevel(long) - Method in interface com.hazelcast.internal.cluster.fd.FailureDetector
Returns suspicion level about the tracked member.
suspicionLevel(Member, long) - Method in class com.hazelcast.internal.cluster.fd.PhiAccrualClusterFailureDetector
 
suspicionLevel(long) - Method in class com.hazelcast.internal.cluster.fd.PhiAccrualFailureDetector
 
swap(long, long) - Method in class com.hazelcast.internal.util.sort.IntMemArrayQuickSorter
 
swap(long, long) - Method in class com.hazelcast.internal.util.sort.LongMemArrayQuickSorter
 
swap(long, long) - Method in class com.hazelcast.internal.util.sort.QuickSorter
Swaps the contents of the slots at the supplied indices.
SwCounter - Class in com.hazelcast.internal.util.counters
A Counter that is made to be used by a single writing thread.
symmetricEncryptionConfig - Variable in class com.hazelcast.config.EndpointConfig
 
SymmetricEncryptionConfig - Class in com.hazelcast.config
Contains configuration for symmetric encryption
SymmetricEncryptionConfig() - Constructor for class com.hazelcast.config.SymmetricEncryptionConfig
 
SYNC_BACKUP_STATE_OP - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
SYNC_DELAY_MS - Static variable in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
SYNC_FREQUENCY - Static variable in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
SYNC_REPLICATED_DATA - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
SYNC_STATE_OP - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
syncAllMaps(String, String) - Method in interface com.hazelcast.wan.impl.WanReplicationService
Initiate wan sync for all maps.
syncAllMaps(String, String) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
 
SyncBackupStateOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
SyncBackupStateOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.SyncBackupStateOperation
 
SyncBackupStateOperation(String, String, Map, ScheduledTaskStatisticsImpl, ScheduledTaskResult) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.SyncBackupStateOperation
 
syncCallOnThis(Operation) - Method in class com.hazelcast.internal.management.ManagementCenterService
 
SynchronousQueueStreamSerializer<E> - Class in com.hazelcast.internal.serialization.impl
The SynchronousQueue serializer Important Note: The `fair` boolean is not be serialized since there is no public way to access it.
SynchronousQueueStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.SynchronousQueueStreamSerializer
 
syncMap(String, String, String) - Method in interface com.hazelcast.wan.impl.WanReplicationService
Initiate wan sync for a specific map.
syncMap(String, String, String) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
 
SyncReplicatedMapDataOperation<K,V> - Class in com.hazelcast.replicatedmap.impl.operation
Carries set of replicated map records for a partition from one node to another
SyncReplicatedMapDataOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.SyncReplicatedMapDataOperation
 
SyncReplicatedMapDataOperation(String, Set<RecordMigrationInfo>, long) - Constructor for class com.hazelcast.replicatedmap.impl.operation.SyncReplicatedMapDataOperation
 
syncState(String, Map, ScheduledTaskStatisticsImpl, ScheduledTaskResult) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
SyncStateOperation - Class in com.hazelcast.scheduledexecutor.impl.operations
 
SyncStateOperation() - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.SyncStateOperation
 
SyncStateOperation(String, String, Map, ScheduledTaskStatisticsImpl, ScheduledTaskResult) - Constructor for class com.hazelcast.scheduledexecutor.impl.operations.SyncStateOperation
 
syncVersion(long) - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
 
SYSPROP_CLIENT_CONFIG - Static variable in class com.hazelcast.internal.config.DeclarativeConfigUtil
System property used for defining the configuring file used for client configuration.
SYSPROP_CLIENT_FAILOVER_CONFIG - Static variable in class com.hazelcast.internal.config.DeclarativeConfigUtil
System property used for defining the configuring file used for client failover configuration.
SYSPROP_MEMBER_CONFIG - Static variable in class com.hazelcast.internal.config.DeclarativeConfigUtil
System property used for defining the configuring file used for member configuration.
SYSTEM_EXECUTOR - Static variable in interface com.hazelcast.spi.impl.executionservice.ExecutionService
Name of the system executor.
SYSTEM_PROPERTY_MULTICAST_GROUP - Static variable in class com.hazelcast.internal.cluster.impl.MulticastService
IP address of a multicast group.
SYSTEM_PROPERTY_SAMPLE_COUNT - Static variable in interface com.hazelcast.map.impl.eviction.Evictor
 
systemLogger - Variable in class com.hazelcast.instance.impl.DefaultNodeExtension
 
SystemLogPlugin - Class in com.hazelcast.internal.diagnostics
The SystemLogPlugin is responsible for: Showing lifecycle changes like shutting down, merging etc. Show connection creation and connection closing.
SystemLogPlugin(NodeEngineImpl) - Constructor for class com.hazelcast.internal.diagnostics.SystemLogPlugin
 
SystemLogPlugin(HazelcastProperties, ConnectionListenable, HazelcastInstance, ILogger) - Constructor for class com.hazelcast.internal.diagnostics.SystemLogPlugin
 
SystemLogPlugin(HazelcastProperties, ConnectionListenable, HazelcastInstance, ILogger, NodeExtension) - Constructor for class com.hazelcast.internal.diagnostics.SystemLogPlugin
 
SystemPropertiesPlugin - Class in com.hazelcast.internal.diagnostics
A DiagnosticsPlugin that displays the system properties.
SystemPropertiesPlugin(NodeEngineImpl) - Constructor for class com.hazelcast.internal.diagnostics.SystemPropertiesPlugin
 
SystemPropertiesPlugin(ILogger) - Constructor for class com.hazelcast.internal.diagnostics.SystemPropertiesPlugin
 

T

tableIndex - Variable in class com.hazelcast.client.impl.protocol.codec.CacheIterateCodec.RequestParameters
The slot number (or index) to start the iterator
tableIndex - Variable in class com.hazelcast.client.impl.protocol.codec.CacheIterateCodec.ResponseParameters
The slot number (or index) to start the iterator
tableIndex - Variable in class com.hazelcast.client.impl.protocol.codec.CacheIterateEntriesCodec.RequestParameters
The slot number (or index) to start the iterator
tableIndex - Variable in class com.hazelcast.client.impl.protocol.codec.CacheIterateEntriesCodec.ResponseParameters
The slot number (or index) to start the iterator
tableIndex - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchEntriesCodec.RequestParameters
The slot number (or index) to start the iterator
tableIndex - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchEntriesCodec.ResponseParameters
The slot number (or index) to start the iterator
tableIndex - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchKeysCodec.RequestParameters
The slot number (or index) to start the iterator
tableIndex - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchKeysCodec.ResponseParameters
The slot number (or index) to start the iterator
tableIndex - Variable in class com.hazelcast.client.impl.protocol.codec.MapFetchWithQueryCodec.RequestParameters
The slot number (or index) to start the iterator
tagFor(AliasedDiscoveryConfig) - Static method in class com.hazelcast.config.AliasedDiscoveryConfigUtils
Returns an XML tag (e.g.
tailEntryOffsets() - Method in class com.hazelcast.cp.internal.raft.impl.persistence.LogFileStructure
 
tailSequence() - Method in class com.hazelcast.client.impl.proxy.ClientRingbufferProxy
 
tailSequence() - Method in class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
 
tailSequence() - Method in interface com.hazelcast.ringbuffer.impl.Ringbuffer
Returns the sequence of the tail.
tailSequence() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
 
tailSequence() - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
 
tailSequence() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Returns the sequence of the tail.
take() - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
take() - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnQueueProxy
 
take() - Method in interface com.hazelcast.collection.BaseQueue
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
take() - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
take() - Method in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxy
 
take() - Method in interface com.hazelcast.collection.IQueue
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
take() - Method in class com.hazelcast.internal.util.concurrent.MPSCQueue
 
take(boolean) - Method in interface com.hazelcast.spi.impl.operationexecutor.impl.OperationQueue
Takes an item from this queue.
take(boolean) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationQueueImpl
 
take() - Method in interface com.hazelcast.transaction.TransactionalQueue
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
takeInputBuffer(Data) - Method in interface com.hazelcast.internal.serialization.impl.bufferpool.BufferPool
Takes an BufferObjectDataInput from the pool and initializes it with the given data.
takeInputBuffer(Data) - Method in class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolImpl
 
takeOutputBuffer() - Method in interface com.hazelcast.internal.serialization.impl.bufferpool.BufferPool
Takes an BufferObjectDataOutput from the pool.
takeOutputBuffer() - Method in class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolImpl
 
takeSnapshot(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueService
 
takeSnapshot(CPGroupId, long) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
takeSnapshot(CPGroupId, long) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
takeSnapshot(long) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftIntegration
Take a snapshot for the given commit index which is the current commit index
takeSnapshot(CPGroupId, long) - Method in interface com.hazelcast.cp.internal.raft.SnapshotAwareService
Creates a snapshot for specified CPGroupId.
takeSnapshot(CPGroupId, long) - Method in class com.hazelcast.cp.internal.RaftService
 
takeSnapshot(CPGroupId, long) - Method in class com.hazelcast.cp.internal.session.RaftSessionService
 
target - Variable in class com.hazelcast.client.impl.protocol.codec.ClientCreateProxyCodec.RequestParameters
TODO DOC
target - Variable in class com.hazelcast.client.impl.protocol.codec.MapClearNearCacheCodec.RequestParameters
TODO DOC
target - Variable in class com.hazelcast.cp.internal.operation.integration.AsyncRaftOp
 
TARGET - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
Target - Class in com.hazelcast.map.impl.query
Target for a query.
Target() - Constructor for class com.hazelcast.map.impl.query.Target
 
target - Variable in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
 
TARGET_DISCONNECTED - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
TARGET_NOT_MEMBER - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
TARGET_NOT_REPLICA_EXCEPTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
TargetAware - Interface in com.hazelcast.spi.impl.operationservice
An Operation that has to be aware of the remote target member address before being serialized and sent over the network can implement TargetAware interface so the target Address will be injected to it.
TargetAwareTransactionLogRecord - Interface in com.hazelcast.transaction.impl
Represents a change made in a transaction on a specific target Address.
TargetDisconnectedException - Exception in com.hazelcast.spi.exception
Thrown when a client invocation is failed because related target is disconnected and whether the invocation is run or not, is indeterminate
TargetDisconnectedException(String) - Constructor for exception com.hazelcast.spi.exception.TargetDisconnectedException
 
TargetDisconnectedException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.TargetDisconnectedException
 
TargetNotMemberException - Exception in com.hazelcast.spi.exception
A RetryableHazelcastException that indicates operation is send to a machine that isn't member of the cluster.
TargetNotMemberException(String) - Constructor for exception com.hazelcast.spi.exception.TargetNotMemberException
 
TargetNotMemberException(Object, int, String, String) - Constructor for exception com.hazelcast.spi.exception.TargetNotMemberException
 
TargetNotReplicaException - Exception in com.hazelcast.crdt
Exception that indicates that the receiver of a CRDT operation is not a CRDT replica.
TargetNotReplicaException(String) - Constructor for exception com.hazelcast.crdt.TargetNotReplicaException
 
targetReplica - Variable in class com.hazelcast.client.impl.protocol.codec.PNCounterAddCodec.RequestParameters
the target replica
targetReplica - Variable in class com.hazelcast.client.impl.protocol.codec.PNCounterGetCodec.RequestParameters
the target replica
task - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToAddressCodec.RequestParameters
Name The name of the task
task - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToPartitionCodec.RequestParameters
Name The name of the task
TASK - Static variable in class com.hazelcast.durableexecutor.impl.DurableExecutorDataSerializerHook
 
TASK_BACKUP - Static variable in class com.hazelcast.durableexecutor.impl.DurableExecutorDataSerializerHook
 
TASK_DESCRIPTOR - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
TASK_HANDLER - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
TASK_INITIAL_DELAY_SECONDS - Static variable in interface com.hazelcast.internal.nearcache.NearCache
 
TASK_PERIOD_SECONDS - Static variable in interface com.hazelcast.internal.nearcache.NearCache
 
TASK_RESOLUTION - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
TASK_STATS - Static variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorDataSerializerHook
 
TaskBackupOperation - Class in com.hazelcast.durableexecutor.impl.operations
 
TaskBackupOperation() - Constructor for class com.hazelcast.durableexecutor.impl.operations.TaskBackupOperation
 
TaskBackupOperation(String, int, Data) - Constructor for class com.hazelcast.durableexecutor.impl.operations.TaskBackupOperation
 
TaskBatch - Class in com.hazelcast.spi.impl.operationexecutor.impl
A 'batch' of tasks to be executed on a partition thread.
TaskBatch(PartitionTaskFactory, BitSet, int, int) - Constructor for class com.hazelcast.spi.impl.operationexecutor.impl.TaskBatch
 
TaskDefinition<V> - Class in com.hazelcast.scheduledexecutor.impl
 
TaskDefinition() - Constructor for class com.hazelcast.scheduledexecutor.impl.TaskDefinition
 
TaskDefinition(TaskDefinition.Type, String, Callable<V>, long, TimeUnit) - Constructor for class com.hazelcast.scheduledexecutor.impl.TaskDefinition
 
TaskDefinition(TaskDefinition.Type, String, Callable<V>, long, long, TimeUnit) - Constructor for class com.hazelcast.scheduledexecutor.impl.TaskDefinition
 
TaskDefinition.Type - Enum in com.hazelcast.scheduledexecutor.impl
 
taskFactory() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.TaskBatch
 
TaskLifecycleListener - Interface in com.hazelcast.scheduledexecutor.impl
 
taskName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromAddressCodec.RequestParameters
The name of the task
taskName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorCancelFromPartitionCodec.RequestParameters
The name of the task
taskName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromAddressCodec.RequestParameters
The name of the task
taskName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorDisposeFromPartitionCodec.RequestParameters
The name of the task
taskName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromAddressCodec.RequestParameters
The name of the task
taskName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetDelayFromPartitionCodec.RequestParameters
The name of the task
taskName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromAddressCodec.RequestParameters
The name of the task
taskName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetResultFromPartitionCodec.RequestParameters
The name of the task
taskName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromAddressCodec.RequestParameters
The name of the task
taskName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromPartitionCodec.RequestParameters
The name of the task
taskName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromAddressCodec.RequestParameters
The name of the task
taskName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsCancelledFromPartitionCodec.RequestParameters
The name of the task
taskName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromAddressCodec.RequestParameters
The name of the task
taskName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorIsDoneFromPartitionCodec.RequestParameters
The name of the task
taskName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToAddressCodec.RequestParameters
The name of the task
taskName - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToPartitionCodec.RequestParameters
The name of the task
taskName - Variable in class com.hazelcast.scheduledexecutor.impl.operations.SyncStateOperation
 
TaskOperation - Class in com.hazelcast.durableexecutor.impl.operations
 
TaskOperation() - Constructor for class com.hazelcast.durableexecutor.impl.operations.TaskOperation
 
TaskOperation(String, Data) - Constructor for class com.hazelcast.durableexecutor.impl.operations.TaskOperation
 
TaskRingBuffer - Class in com.hazelcast.durableexecutor.impl
A RingBuffer implementation to store tasks and results of those task Only a single thread (partition-operation-thread) accesses the instance
TaskRingBuffer() - Constructor for class com.hazelcast.durableexecutor.impl.TaskRingBuffer
 
TaskRingBuffer(int) - Constructor for class com.hazelcast.durableexecutor.impl.TaskRingBuffer
 
TaskRingBuffer.DurableIterator - Class in com.hazelcast.durableexecutor.impl
 
tasks - Variable in class com.hazelcast.scheduledexecutor.impl.ScheduledExecutorContainer
 
TaskScheduler - Interface in com.hazelcast.spi.impl.executionservice
ExecutorService can schedule a command to run after a given delay or execute periodically.
TaskUtils - Class in com.hazelcast.scheduledexecutor
A helper class with utilities to act upon Runnable and/or Callable tasks.
TCKMBeanServerBuilder - Class in com.hazelcast.cache.impl
An MBeanServer builder required by TCK tests.
TCKMBeanServerBuilder() - Constructor for class com.hazelcast.cache.impl.TCKMBeanServerBuilder
 
TCKMBeanServerBuilder.RIMBeanServerDelegate - Class in com.hazelcast.cache.impl
 
TCP_JOIN_PORT_TRY_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
The number of incremental ports, starting with port number defined in network configuration, that will be used to connect to a host which is defined without a port in the TCP-IP member list while a node is searching for a cluster.
TCP_NODELAY - Static variable in class com.hazelcast.internal.networking.ChannelOption
TcpIpAcceptor - Class in com.hazelcast.internal.nio.tcp
Contains the logic for accepting TcpIpConnections.
TcpIpConfig - Class in com.hazelcast.config
Contains the configuration for the Tcp/Ip join mechanism.
TcpIpConfig() - Constructor for class com.hazelcast.config.TcpIpConfig
 
TcpIpConnection - Class in com.hazelcast.internal.nio.tcp
The Tcp/Ip implementation of the Connection.
TcpIpConnection(TcpIpEndpointManager, ConnectionLifecycleListener, int, Channel) - Constructor for class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
TcpIpConnectionChannelErrorHandler - Class in com.hazelcast.internal.nio.tcp
 
TcpIpConnectionChannelErrorHandler(ILogger) - Constructor for class com.hazelcast.internal.nio.tcp.TcpIpConnectionChannelErrorHandler
 
TcpIpConnectionErrorHandler - Class in com.hazelcast.internal.nio.tcp
 
TcpIpEndpointManager - Class in com.hazelcast.internal.nio.tcp
 
TcpIpEndpointManager.EndpointConnectionLifecycleListener - Class in com.hazelcast.internal.nio.tcp
 
TcpIpJoiner - Class in com.hazelcast.internal.cluster.impl
 
TcpIpJoiner(Node) - Constructor for class com.hazelcast.internal.cluster.impl.TcpIpJoiner
 
TcpIpNetworkingService - Class in com.hazelcast.internal.nio.tcp
 
TcpIpNetworkingService(Config, IOService, ServerSocketRegistry, LoggingService, MetricsRegistry, Networking, ChannelInitializerProvider, HazelcastProperties) - Constructor for class com.hazelcast.internal.nio.tcp.TcpIpNetworkingService
 
TENANT_CONTROL_FACTORY - Static variable in class com.hazelcast.cache.impl.AbstractCacheService
 
tenantContext - Variable in class com.hazelcast.cache.impl.operation.CacheOperation
 
TenantControl - Interface in com.hazelcast.spi.tenantcontrol
Hooks for multi-tenancy for application servers Hazelcast uses separate threads to invoke operations this interface acts a hook to establish a thread-local tenant context so that operation invocations into application servers are handled correctly This is used by application servers to establish thread context for class loading, CDI, EJB and JPA invocations
TenantControlFactory - Interface in com.hazelcast.spi.tenantcontrol
A TenantControlFactory supplies TenantControl objects when Hazelcast service attaches the tenant control to a distributed object.
term() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendFailureResponse
 
term() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendRequest
 
term() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendSuccessResponse
 
term() - Method in class com.hazelcast.cp.internal.raft.impl.dto.InstallSnapshot
 
term() - Method in class com.hazelcast.cp.internal.raft.impl.dto.PreVoteResponse
 
term() - Method in class com.hazelcast.cp.internal.raft.impl.dto.TriggerLeaderElection
 
term() - Method in class com.hazelcast.cp.internal.raft.impl.dto.VoteRequest
 
term() - Method in class com.hazelcast.cp.internal.raft.impl.dto.VoteResponse
 
term() - Method in class com.hazelcast.cp.internal.raft.impl.log.LogEntry
 
term() - Method in class com.hazelcast.cp.internal.raft.impl.persistence.RestoredRaftState
 
term() - Method in class com.hazelcast.cp.internal.raft.impl.state.LeadershipTransferState
 
term() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns the latest term this node has seen
term - Variable in class com.hazelcast.cp.internal.RaftNodeMetrics
 
TermChangeAwareService - Interface in com.hazelcast.cp.internal
Services can implement this interface to get notified when there is a leader change in a Raft group.
terminate() - Method in class com.hazelcast.client.impl.clientside.LifecycleServiceImpl
 
terminate() - Method in interface com.hazelcast.core.LifecycleService
Terminate HazelcastInstance ungracefully.
terminate() - Method in class com.hazelcast.instance.impl.LifecycleServiceImpl
 
terminate() - Method in class com.hazelcast.instance.impl.TerminatedLifecycleService
 
TERMINATE_TIMEOUT_SECONDS - Static variable in class com.hazelcast.client.impl.spi.impl.ClientExecutionServiceImpl
 
terminateAll() - Static method in class com.hazelcast.instance.impl.HazelcastInstanceFactory
 
TerminatedLifecycleService - Class in com.hazelcast.instance.impl
 
TerminatedLifecycleService() - Constructor for class com.hazelcast.instance.impl.TerminatedLifecycleService
 
test(T, U) - Method in interface com.hazelcast.internal.util.function.BiPredicateEx
 
test(T) - Method in interface com.hazelcast.internal.util.function.PredicateEx
 
test(T) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.IPredicate
Evaluates this predicate on the given argument.
test(DiscoveryNode) - Method in interface com.hazelcast.spi.discovery.NodeFilter
Accepts or denies a DiscoveryNode based on the implemented rules.
testEx(T, U) - Method in interface com.hazelcast.internal.util.function.BiPredicateEx
Exception-declaring version of BiPredicate.test(T, U).
testEx(T) - Method in interface com.hazelcast.internal.util.function.PredicateEx
Exception-declaring version of Predicate.test(T).
testValue - Variable in class com.hazelcast.client.impl.protocol.codec.MapReplaceIfSameCodec.RequestParameters
Test the existing value against this value to find if equal to this value.
TEXT_ENCODER - Static variable in class com.hazelcast.internal.nio.ascii.TextEncoder
 
TEXT_PARSERS - Static variable in class com.hazelcast.internal.nio.ascii.MemcacheTextDecoder
 
TEXT_PARSERS - Static variable in class com.hazelcast.internal.nio.ascii.RestApiTextDecoder
 
TEXT_PROTOCOLS_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
TEXT_PROTOCOLS_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
TextChannelInitializer - Class in com.hazelcast.internal.nio.ascii
 
TextChannelInitializer(IOService, EndpointConfig, boolean) - Constructor for class com.hazelcast.internal.nio.ascii.TextChannelInitializer
 
TextCommand - Interface in com.hazelcast.internal.ascii
 
TextCommandConstants - Class in com.hazelcast.internal.ascii
 
TextCommandConstants.TextCommandType - Enum in com.hazelcast.internal.ascii
 
TextCommandProcessor<T> - Interface in com.hazelcast.internal.ascii
 
textCommandService - Variable in class com.hazelcast.instance.impl.Node
 
textCommandService - Variable in class com.hazelcast.internal.ascii.AbstractTextCommandProcessor
 
TextCommandService - Interface in com.hazelcast.internal.ascii
 
TextCommandServiceImpl - Class in com.hazelcast.internal.ascii
 
TextCommandServiceImpl(Node) - Constructor for class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
TextDecoder - Class in com.hazelcast.internal.nio.ascii
 
TextDecoder(TcpIpConnection, TextEncoder, TextProtocolFilter, TextParsers, boolean) - Constructor for class com.hazelcast.internal.nio.ascii.TextDecoder
 
TextEncoder - Class in com.hazelcast.internal.nio.ascii
 
TextEncoder(TcpIpConnection) - Constructor for class com.hazelcast.internal.nio.ascii.TextEncoder
 
TextHandshakeDecoder - Class in com.hazelcast.internal.nio.tcp
 
TextHandshakeDecoder(ProtocolType, InboundHandler) - Constructor for class com.hazelcast.internal.nio.tcp.TextHandshakeDecoder
 
TextParsers - Class in com.hazelcast.internal.nio.ascii
 
TextParsers(Map<String, CommandParser>) - Constructor for class com.hazelcast.internal.nio.ascii.TextParsers
 
TextProtocolsDataSerializerHook - Class in com.hazelcast.internal.ascii
DataSerializerHook for memcache & REST protocol support classes
TextProtocolsDataSerializerHook() - Constructor for class com.hazelcast.internal.ascii.TextProtocolsDataSerializerHook
 
TextViewUnifiedEndpointManager - Class in com.hazelcast.internal.nio.tcp
 
TheByteArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.TheByteArraySerializer
 
thenAccept(Consumer<? super V>) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
thenAccept(Consumer<? super V>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
thenAccept(Consumer<? super V>) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
thenAccept(Consumer<? super V>) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
thenAcceptAsync(Consumer<? super V>) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
thenAcceptAsync(Consumer<? super V>, Executor) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
thenAcceptAsync(Consumer<? super ClientMessage>, Executor) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
thenAcceptAsync(Consumer<? super V>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
thenAcceptAsync(Consumer<? super V>, Executor) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
thenAcceptAsync(Consumer<? super V>) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
thenAcceptAsync(Consumer<? super V>, Executor) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
thenAcceptAsync(Consumer<? super V>) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
thenAcceptAsync(Consumer<? super V>, Executor) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
thenAcceptBoth(CompletionStage<? extends U>, BiConsumer<? super V, ? super U>) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
thenAcceptBoth(CompletionStage<? extends U>, BiConsumer<? super V, ? super U>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
thenAcceptBoth(CompletionStage<? extends U>, BiConsumer<? super V, ? super U>) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
thenAcceptBoth(CompletionStage<? extends U>, BiConsumer<? super V, ? super U>) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super V, ? super U>) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super V, ? super U>, Executor) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super ClientMessage, ? super U>, Executor) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super V, ? super U>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super V, ? super U>, Executor) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super V, ? super U>) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super V, ? super U>, Executor) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super V, ? super U>) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super V, ? super U>, Executor) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
thenApply(Function<? super V, ? extends U>) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
thenApply(Function<? super V, ? extends U>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
thenApply(Function<? super V, ? extends U>) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
thenApply(Function<? super V, ? extends U>) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
thenApplyAsync(Function<? super V, ? extends U>) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
thenApplyAsync(Function<? super V, ? extends U>, Executor) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
thenApplyAsync(Function<? super ClientMessage, ? extends U>, Executor) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
thenApplyAsync(Function<? super V, ? extends U>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
thenApplyAsync(Function<? super V, ? extends U>, Executor) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
thenApplyAsync(Function<? super V, ? extends U>) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
thenApplyAsync(Function<? super V, ? extends U>, Executor) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
thenApplyAsync(Function<? super V, ? extends U>) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
thenApplyAsync(Function<? super V, ? extends U>, Executor) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
thenCombine(CompletionStage<? extends U>, BiFunction<? super V, ? super U, ? extends V1>) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
thenCombine(CompletionStage<? extends U>, BiFunction<? super V, ? super U, ? extends R>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
thenCombine(CompletionStage<? extends U>, BiFunction<? super V, ? super U, ? extends V1>) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
thenCombine(CompletionStage<? extends U>, BiFunction<? super V, ? super U, ? extends V1>) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super V, ? super U, ? extends V1>) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super V, ? super U, ? extends V1>, Executor) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super ClientMessage, ? super U, ? extends R>, Executor) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super V, ? super U, ? extends R>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super V, ? super U, ? extends R>, Executor) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super V, ? super U, ? extends V1>) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super V, ? super U, ? extends V1>, Executor) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super V, ? super U, ? extends V1>) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super V, ? super U, ? extends V1>, Executor) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
thenComparing(Comparator<? super T>) - Method in interface com.hazelcast.internal.util.function.ComparatorEx
thenComparing(ComparatorEx<? super T>) - Method in interface com.hazelcast.internal.util.function.ComparatorEx
thenComparing(Function<? super T, ? extends U>, Comparator<? super U>) - Method in interface com.hazelcast.internal.util.function.ComparatorEx
thenComparing(FunctionEx<? super T, ? extends U>, ComparatorEx<? super U>) - Method in interface com.hazelcast.internal.util.function.ComparatorEx
thenComparing(Function<? super T, ? extends U>) - Method in interface com.hazelcast.internal.util.function.ComparatorEx
thenComparing(FunctionEx<? super T, ? extends U>) - Method in interface com.hazelcast.internal.util.function.ComparatorEx
thenComparingDouble(ToDoubleFunction<? super T>) - Method in interface com.hazelcast.internal.util.function.ComparatorEx
thenComparingDouble(ToDoubleFunctionEx<? super T>) - Method in interface com.hazelcast.internal.util.function.ComparatorEx
thenComparingInt(ToIntFunction<? super T>) - Method in interface com.hazelcast.internal.util.function.ComparatorEx
thenComparingInt(ToIntFunctionEx<? super T>) - Method in interface com.hazelcast.internal.util.function.ComparatorEx
thenComparingLong(ToLongFunction<? super T>) - Method in interface com.hazelcast.internal.util.function.ComparatorEx
thenComparingLong(ToLongFunctionEx<? super T>) - Method in interface com.hazelcast.internal.util.function.ComparatorEx
thenCompose(Function<? super V, ? extends CompletionStage<U>>) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
thenCompose(Function<? super V, ? extends CompletionStage<U>>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
thenCompose(Function<? super V, ? extends CompletionStage<U>>) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
thenCompose(Function<? super V, ? extends CompletionStage<U>>) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
thenComposeAsync(Function<? super V, ? extends CompletionStage<U>>) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
thenComposeAsync(Function<? super V, ? extends CompletionStage<U>>, Executor) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
thenComposeAsync(Function<? super ClientMessage, ? extends CompletionStage<U>>, Executor) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
thenComposeAsync(Function<? super V, ? extends CompletionStage<U>>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
thenComposeAsync(Function<? super V, ? extends CompletionStage<U>>, Executor) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
thenComposeAsync(Function<? super V, ? extends CompletionStage<U>>) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
thenComposeAsync(Function<? super V, ? extends CompletionStage<U>>, Executor) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
thenComposeAsync(Function<? super V, ? extends CompletionStage<U>>) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
thenComposeAsync(Function<? super V, ? extends CompletionStage<U>>, Executor) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
thenRun(Runnable) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
thenRun(Runnable) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
thenRun(Runnable) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
thenRun(Runnable) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
thenRunAsync(Runnable) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
thenRunAsync(Runnable, Executor) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
thenRunAsync(Runnable, Executor) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
thenRunAsync(Runnable) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
thenRunAsync(Runnable, Executor) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
thenRunAsync(Runnable) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
thenRunAsync(Runnable, Executor) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
thenRunAsync(Runnable) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
thenRunAsync(Runnable, Executor) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
thisAddress - Variable in class com.hazelcast.map.impl.recordstore.AbstractEvictableRecordStore
 
THREAD_ID_GENERATOR - Static variable in class com.hazelcast.internal.util.executor.StripedExecutor
 
THREAD_LOCAL_CLASS_CACHE - Static variable in class com.hazelcast.internal.usercodedeployment.impl.ThreadLocalClassCache
 
ThreadDumpGenerator - Class in com.hazelcast.internal.management
Generates thread dumps.
ThreadDumpOperation - Class in com.hazelcast.internal.management.operation
Operation for generating thread dumps.
ThreadDumpOperation(boolean) - Constructor for class com.hazelcast.internal.management.operation.ThreadDumpOperation
 
ThreadDumpRequest - Class in com.hazelcast.internal.management.request
Request for generating thread dumps.
ThreadDumpRequest() - Constructor for class com.hazelcast.internal.management.request.ThreadDumpRequest
 
ThreadDumpRequest(boolean) - Constructor for class com.hazelcast.internal.management.request.ThreadDumpRequest
 
ThreadFactoryImpl - Class in com.hazelcast.internal.util.concurrent
 
ThreadFactoryImpl(String) - Constructor for class com.hazelcast.internal.util.concurrent.ThreadFactoryImpl
 
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockGetLockOwnershipCodec.ResponseParameters
TODO DOC
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockLockCodec.RequestParameters
ID of the caller thread
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockTryLockCodec.RequestParameters
ID of the caller thread
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockUnlockCodec.RequestParameters
ID of the caller thread
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapContainsKeyCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapDeleteCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapEvictCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapExecuteOnKeyCodec.RequestParameters
TODO DOC
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapGetCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapGetEntryViewCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapLockCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentWithMaxIdleCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutTransientCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutTransientWithMaxIdleCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutWithMaxIdleCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveIfSameCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapReplaceCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapReplaceIfSameCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapSetCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapSetWithMaxIdleCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapSubmitToKeyCodec.RequestParameters
TODO DOC
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapTryLockCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapTryPutCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapTryRemoveCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MapUnlockCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsEntryCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsKeyCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapDeleteCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapGetCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapLockCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapPutCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapTryLockCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapUnlockCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapValueCountCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreAcquireCodec.RequestParameters
ID of the caller thread
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreChangeCodec.RequestParameters
ID of the caller thread
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreDrainCodec.RequestParameters
ID of the caller thread
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreReleaseCodec.RequestParameters
ID of the caller thread
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListAddCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListRemoveCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListSizeCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsKeyCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsValueCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapDeleteCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetForUpdateCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapIsEmptyCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetWithPredicateCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutIfAbsentCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveIfSameCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceIfSameCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSetCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSizeCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesWithPredicateCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapGetCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapPutCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveEntryCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapSizeCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapValueCountCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueOfferCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePeekCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePollCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueSizeCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueTakeCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetAddCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetRemoveCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetSizeCodec.RequestParameters
The id of the user thread performing the operation.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionCommitCodec.RequestParameters
The thread id for the transaction.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionCreateCodec.RequestParameters
The thread id for the transaction.
threadId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionRollbackCodec.RequestParameters
The thread id for the transaction.
threadId() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockEndpoint
 
threadId() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreEndpoint
 
threadId - Variable in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
threadId - Variable in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
 
threadId - Variable in class com.hazelcast.map.impl.operation.ReadonlyKeyBasedMapOperation
 
threadId - Variable in class com.hazelcast.multimap.impl.operations.AbstractKeyBasedMultiMapOperation
 
ThreadLocalClassCache - Class in com.hazelcast.internal.usercodedeployment.impl
Thread-Local Class Cache is useful when the regular class-cache is disabled - we want to keep classes cached at very least for the duration of a single deserialization request.
ThreadLocalRandomProvider - Class in com.hazelcast.internal.util
A random number generator isolated to the current thread.
ThreadMetricSet - Class in com.hazelcast.internal.metrics.metricsets
A Metric pack for exposing ThreadMXBean metric.
threadNamePrefix(String) - Method in class com.hazelcast.internal.networking.nio.NioNetworking.Context
 
ThreadUtil - Class in com.hazelcast.internal.util
Utility class to manipulate and query thread ID.
THRESHOLD - Static variable in class com.hazelcast.internal.diagnostics.EventQueuePlugin
The minimum number of events in the queue before it is being sampled.
THRESHOLD - Static variable in class com.hazelcast.internal.diagnostics.OverloadedConnectionsPlugin
The minimum number of packets in the connection before it is considered to be overloaded.
THRESHOLD - Static variable in class com.hazelcast.internal.diagnostics.PendingInvocationsPlugin
The minimum number of invocations per type of operation before it start logging this particular operation.
throwNotActiveException() - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
 
throwNotActiveException() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
throwNotActiveException() - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
throwUnacceptedSuffixInSystemProperty(String, String, Collection<String>) - Static method in class com.hazelcast.internal.config.DeclarativeConfigUtil
Throws HazelcastException unconditionally referring to that the configuration file referenced in the system property propertyKey has a suffix not in the accepted suffix list defined in acceptedSuffixes.
TIME_NOT_AVAILABLE - Static variable in interface com.hazelcast.cache.impl.record.CacheRecord
Represents invalid (not set) time for creation time, expiration time, access time, etc...
TIME_NOT_SET - Static variable in interface com.hazelcast.internal.nearcache.NearCacheRecord
 
timedExpiryPolicyFactoryConfig - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
expiry policy factory with duration configuration
TimedExpiryPolicyFactoryConfig() - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
TimedExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType, CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
TimedExpiryPolicyFactoryConfigCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
TimedMemberState - Class in com.hazelcast.internal.management
Container for a MemberState with a timestamp.
TimedMemberState() - Constructor for class com.hazelcast.internal.management.TimedMemberState
 
TimedMemberStateFactory - Class in com.hazelcast.internal.management
A Factory for creating TimedMemberState instances.
TimedMemberStateFactory(HazelcastInstanceImpl) - Constructor for class com.hazelcast.internal.management.TimedMemberStateFactory
 
timeInMsOrOneIfResultIsZero(long, TimeUnit) - Static method in class com.hazelcast.internal.util.TimeUtil
Convert time to milliseconds based on the given time unit.
timeInMsOrTimeIfNullUnit(long, TimeUnit) - Static method in class com.hazelcast.internal.util.TimeUtil
Convert time to milliseconds based on the given time unit.
TIMEOUT - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
timeout - Variable in class com.hazelcast.client.impl.protocol.codec.MapTryLockCodec.RequestParameters
maximum time to wait for getting the lock.
timeout - Variable in class com.hazelcast.client.impl.protocol.codec.MapTryPutCodec.RequestParameters
maximum time in milliseconds to wait for acquiring the lock for the key.
timeout - Variable in class com.hazelcast.client.impl.protocol.codec.MapTryRemoveCodec.RequestParameters
maximum time in milliseconds to wait for acquiring the lock for the key.
timeout - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapTryLockCodec.RequestParameters
Maximum time to wait for the lock.
timeout - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueOfferCodec.RequestParameters
How long to wait before giving up, in milliseconds
timeout - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePeekCodec.RequestParameters
How long to wait before giving up, in milliseconds
timeout - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePollCodec.RequestParameters
How long to wait before giving up, in milliseconds
timeout - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionCreateCodec.RequestParameters
The maximum allowed duration for the transaction operations.
timeout - Variable in class com.hazelcast.client.impl.protocol.codec.XATransactionCreateCodec.RequestParameters
The timeout in seconds for XA operations such as prepare, commit, rollback.
timeoutMillis - Variable in class com.hazelcast.client.impl.protocol.codec.QueueOfferCodec.RequestParameters
Maximum time in milliseconds to wait for acquiring the lock for the key.
timeoutMillis - Variable in class com.hazelcast.client.impl.protocol.codec.QueuePollCodec.RequestParameters
Maximum time in milliseconds to wait for acquiring the lock for the key.
timeoutMs - Variable in class com.hazelcast.client.impl.protocol.codec.CountDownLatchAwaitCodec.RequestParameters
The maximum time in milliseconds to wait
timeoutMs - Variable in class com.hazelcast.client.impl.protocol.codec.FencedLockTryLockCodec.RequestParameters
Duration to wait for lock acquire
timeoutMs - Variable in class com.hazelcast.client.impl.protocol.codec.SemaphoreAcquireCodec.RequestParameters
Duration to wait for permit acquire
TimeoutRunnable - Interface in com.hazelcast.internal.util.executor
Interface for runnable with timeout value
timestamp(long) - Method in interface com.hazelcast.internal.auditlog.EventBuilder
If provided value greater than zero, then it sets the event timestamp explicitly.
timestamp(long) - Method in class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService.Builder
 
timeToLiveMillis - Variable in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
timeToLiveSeconds - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
maximum number of seconds for each entry to stay in the map.
timeToLiveSeconds - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddRingbufferConfigCodec.RequestParameters
maximum number of seconds for each entry to stay in the ringbuffer
timeToString(long) - Static method in class com.hazelcast.internal.util.StringUtil
Returns a String representation of the time.
timeToStringFriendly(long) - Static method in class com.hazelcast.internal.util.StringUtil
Returns a String representation of the time.
TimeUtil - Class in com.hazelcast.internal.util
Utility class for Time & unit conversions
TlsAuthenticationConfig - Class in com.hazelcast.config.security
Typed authentication configuration for the X509CertificateLoginModule.
TlsAuthenticationConfig() - Constructor for class com.hazelcast.config.security.TlsAuthenticationConfig
 
to - Variable in class com.hazelcast.client.impl.protocol.codec.ListSubCodec.RequestParameters
High endpoint (exclusive) of the subList
toAccumulatorInfo(QueryCacheConfig, String, String, Predicate) - Static method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
 
toAccumulatorInfo(String, String, Predicate, int, int, long, boolean, boolean, boolean) - Static method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
 
toArray() - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
toArray(T[]) - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
toArray() - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
toArray(T[]) - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
toArray() - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
toArray(T[]) - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
toArray() - Method in class com.hazelcast.client.impl.proxy.ClientSetProxy
 
toArray(T[]) - Method in class com.hazelcast.client.impl.proxy.ClientSetProxy
 
toArray() - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
toArray(T[]) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
toArray() - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
 
toArray(T[]) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
 
toArray() - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
toArray(T[]) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
toArray() - Method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
 
toArray(T[]) - Method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
 
toArray() - Method in class com.hazelcast.internal.util.collection.IntHashSet
 
toArray(T[]) - Method in class com.hazelcast.internal.util.collection.IntHashSet
 
toArray() - Method in class com.hazelcast.internal.util.collection.LongHashSet
toArray(T[]) - Method in class com.hazelcast.internal.util.collection.LongHashSet
toArray() - Method in class com.hazelcast.internal.util.collection.OAHashSet
 
toArray(T[]) - Method in class com.hazelcast.internal.util.collection.OAHashSet
 
toBackupSender - Variable in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
ToBackupSender<RS> - Class in com.hazelcast.internal.eviction
Helper class to create and send backup expiration operations.
toByteArray(Object) - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
toByteArray(Object) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
toByteArray(InputStream) - Static method in class com.hazelcast.internal.nio.IOUtil
 
toByteArray() - Method in class com.hazelcast.internal.serialization.impl.HeapData
 
toByteArray() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
toByteArray(int) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
toByteArray() - Method in interface com.hazelcast.nio.ObjectDataOutput
 
toByteArray(int) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
toByteArray() - Method in interface com.hazelcast.nio.serialization.Data
Returns byte array representation of internal binary format.
toBytes(Object) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
toBytes(Object, int, boolean) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
toBytes(Object) - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
Writes the obj to a byte array.
toBytes(Object, int, boolean) - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
Writes an object to a byte-array.
toBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
 
toCandidate(boolean) - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Switches this node to candidate role.
toCompletableFuture() - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
toCompletableFuture() - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
toCompletableFuture() - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
toData(Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
toData(Object) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
toData(Object) - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
toData(Object) - Method in class com.hazelcast.cache.impl.ClusterWideIterator
 
toData(Object) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
 
toData(Object) - Method in class com.hazelcast.client.cache.impl.ClientClusterWideIterator
 
toData(T) - Method in class com.hazelcast.client.impl.spi.ClientProxy
 
toData(Object) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
toData(Object) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
toData(Object, PartitioningStrategy) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
toData(Object, DataType) - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1
 
toData(Object, DataType, PartitioningStrategy) - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1
 
toData(Object, DataType) - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
 
toData(Object, DataType, PartitioningStrategy) - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
 
toData(Object) - Method in interface com.hazelcast.internal.serialization.SerializationService
Serializes an object to a Data.
toData(Object, PartitioningStrategy) - Method in interface com.hazelcast.internal.serialization.SerializationService
Serializes an object to a Data.
toData() - Method in class com.hazelcast.map.impl.MapContainer
 
toData(Object, PartitioningStrategy) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
toData(Object) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
toData(T) - Method in class com.hazelcast.map.impl.query.PartitionScanRunner
 
toData(Object) - Method in class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
 
toData(Object) - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
toData(Object) - Method in class com.hazelcast.spi.impl.merge.AbstractMergeRunnable
 
toData(Object) - Method in interface com.hazelcast.spi.impl.NodeEngine
Serializes an object to a Data.
toData(Object) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
toDataFunction - Variable in class com.hazelcast.map.impl.MapContainer
 
toDebugString(String, ByteBuffer) - Static method in class com.hazelcast.internal.nio.IOUtil
Creates a debug String for te given ByteBuffer.
ToDoubleFunctionEx<T> - Interface in com.hazelcast.internal.util.function
Serializable variant of java.util.function.ToDoubleFunction which declares checked exception.
toEntry(String, Object) - Method in class com.hazelcast.internal.ascii.memcache.EntryConverter
 
toEventData(Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
toFileName(String) - Static method in class com.hazelcast.internal.nio.IOUtil
 
toFollower(int) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Switches this node to follower role by clearing the known leader endpoint and (pre) candidate states, and updating the term.
toFollower(int) - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Switches this node to follower role.
toGigaBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
 
toHeapData(Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
toHeapData(Object) - Method in class com.hazelcast.cache.impl.CacheRecordStore
 
toHeapData(Data) - Static method in class com.hazelcast.internal.util.ToHeapDataConverter
Converts Data to HeapData.
toHeapData(Object) - Method in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
 
toHeapData(Object) - Method in class com.hazelcast.spi.impl.merge.AbstractMergeRunnable
 
ToHeapDataConverter - Class in com.hazelcast.internal.util
Converts any Data implementation to HeapData
toHumanReadableMillis(long) - Static method in class com.hazelcast.internal.util.TimeUtil
 
toIntArray(Collection<Integer>) - Static method in class com.hazelcast.internal.util.CollectionUtil
Converts a Collection of Integer to a primitive int[] array.
ToIntFunctionEx<T> - Interface in com.hazelcast.internal.util.function
Serializable variant of java.util.function.ToIntFunction which declares checked exception.
toJson() - Method in class com.hazelcast.internal.management.dto.AliasedDiscoveryConfigDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.ClientBwListDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.ClientBwListEntryDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.ClientEndPointDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.ClusterHotRestartStatusDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.ConnectionManagerDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.CustomWanPublisherConfigDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.DiscoveryConfigDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.DiscoveryStrategyConfigDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.EventServiceDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.ManagedExecutorDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.MapConfigDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.OperationServiceDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.PartitionServiceBeanDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.PermissionConfigDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.ProxyServiceDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.SlowOperationDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.SlowOperationInvocationDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.WanBatchReplicationPublisherConfigDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.WanConsumerConfigDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.WanReplicationConfigDTO
 
toJson() - Method in class com.hazelcast.internal.management.dto.WanSyncConfigDTO
 
toJson() - Method in class com.hazelcast.internal.management.events.AbstractWanAntiEntropyEventBase
 
toJson() - Method in class com.hazelcast.internal.management.events.AddWanConfigIgnoredEvent
 
toJson() - Method in interface com.hazelcast.internal.management.events.Event
Serialize the event as JSON, for sending to Management Center.
toJson() - Method in class com.hazelcast.internal.management.events.EventBatch
 
toJson() - Method in class com.hazelcast.internal.management.events.EventMetadata
 
toJson() - Method in class com.hazelcast.internal.management.events.WanConfigurationAddedEvent
 
toJson() - Method in class com.hazelcast.internal.management.events.WanConfigurationExtendedEvent
 
toJson() - Method in class com.hazelcast.internal.management.events.WanConsistencyCheckFinishedEvent
 
toJson() - Method in class com.hazelcast.internal.management.events.WanConsistencyCheckIgnoredEvent
 
toJson() - Method in class com.hazelcast.internal.management.events.WanMerkleSyncFinishedEvent
 
toJson() - Method in class com.hazelcast.internal.management.events.WanSyncIgnoredEvent
 
toJson() - Method in class com.hazelcast.internal.management.events.WanSyncProgressUpdateEvent
 
toJson() - Method in interface com.hazelcast.internal.management.JsonSerializable
Serializes state represented by this object into a JsonObject.
toJson() - Method in class com.hazelcast.internal.management.request.UpdatePermissionConfigRequest
 
toJson() - Method in class com.hazelcast.internal.management.TimedMemberState
 
toJson(Object) - Static method in class com.hazelcast.internal.util.JsonUtil
Returns the JSON representation of the provided value
toJson() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
toJson() - Method in class com.hazelcast.monitor.impl.HotRestartStateImpl
 
toJson() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
 
toJson() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
 
toJson() - Method in class com.hazelcast.monitor.impl.LocalFlakeIdGeneratorStatsImpl
 
toJson() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
 
toJson() - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
 
toJson() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
toJson() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
toJson() - Method in class com.hazelcast.monitor.impl.LocalOperationStatsImpl
 
toJson() - Method in class com.hazelcast.monitor.impl.LocalPNCounterStatsImpl
 
toJson() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
toJson() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
toJson() - Method in class com.hazelcast.monitor.impl.LocalTopicStatsImpl
 
toJson() - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
toJson() - Method in class com.hazelcast.monitor.impl.LocalWanStatsImpl
 
toJson() - Method in class com.hazelcast.monitor.impl.MemberPartitionStateImpl
 
toJson() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
toJson() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
toJson() - Method in class com.hazelcast.monitor.impl.NodeStateImpl
 
toJson() - Method in class com.hazelcast.monitor.impl.WanSyncStateImpl
 
toJsonObject(Map<String, ?>) - Static method in class com.hazelcast.internal.util.JsonUtil
Transforms the provided map of name/value pairs into a JsonObject.
TokenCredentials - Interface in com.hazelcast.security
Credentials type for custom authentication (token based).
TokenEncoding - Enum in com.hazelcast.config.security
Possible token encodings.
TokenIdentityConfig - Class in com.hazelcast.config.security
Simple token identity configuration.
TokenIdentityConfig(TokenEncoding, String) - Constructor for class com.hazelcast.config.security.TokenIdentityConfig
 
TokenIdentityConfig(byte[]) - Constructor for class com.hazelcast.config.security.TokenIdentityConfig
 
tokenizeVersionString(String) - Static method in class com.hazelcast.internal.util.StringUtil
Tokenizes a version string and returns the tokens with the following grouping: (1) major version, eg "3" (2) minor version, eg "8" (3) patch version prefixed with ".", if exists, otherwise null (eg ".0") (4) patch version, eg "0" (5) 1st -qualifier, if exists (6) -SNAPSHOT qualifier, if exists
toKiloBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
 
toLeader() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Switches this Raft node to the leader role by performing the following steps: Setting the local endpoint as the current leader, Clearing (pre)candidate states, Initializing the leader state for the current members, Appending an operation to the Raft log if enabled, Scheduling the periodic heartbeat task, Printing the member state.
toLeader() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Switches this node to leader role.
toLongArray(Collection<Long>) - Static method in class com.hazelcast.internal.util.CollectionUtil
Converts a Collection of Long to a primitive long[] array.
ToLongFunctionEx<T> - Interface in com.hazelcast.internal.util.function
Serializable variant of java.util.function.ToLongFunction which declares checked exception.
toMap(Properties) - Static method in class com.hazelcast.client.impl.protocol.util.PropertiesUtil
 
toMD5String(String) - Static method in class com.hazelcast.internal.util.MD5Util
Converts given string to MD5 hash
toMegaBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
 
toMember() - Method in class com.hazelcast.internal.cluster.MemberInfo
 
toMemberInfo() - Method in class com.hazelcast.internal.cluster.impl.JoinRequest
 
toMetricsPrefixString() - Method in class com.hazelcast.instance.EndpointQualifier
 
toMigrationState() - Method in class com.hazelcast.internal.partition.impl.MigrationStats
 
toNewBuffer() - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
 
toObject(Object) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
toObject(Object) - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
toObject(Object) - Method in class com.hazelcast.cache.impl.ClusterWideIterator
 
toObject(Object) - Method in class com.hazelcast.client.cache.impl.ClientClusterWideIterator
 
toObject(Object) - Method in class com.hazelcast.client.impl.querycache.ClientQueryCacheContext
 
toObject(Object) - Method in class com.hazelcast.client.impl.spi.ClientProxy
 
toObject(Object) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
toObject(Object, Class) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
toObject(Object) - Method in interface com.hazelcast.internal.serialization.SerializationService
Deserializes an object.
toObject(Object, Class) - Method in interface com.hazelcast.internal.serialization.SerializationService
Deserializes an object.
toObject(Object) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
toObject(Object) - Method in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
 
toObject(Object) - Method in class com.hazelcast.map.impl.querycache.NodeQueryCacheContext
 
toObject(Object) - Method in interface com.hazelcast.map.impl.querycache.QueryCacheContext
Helper method to convert provided Data to its object form.
toObject(Object) - Method in class com.hazelcast.map.impl.querycache.subscriber.AbstractQueryCacheEndToEndConstructor
 
toObject(Object) - Method in class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
 
toObject(Object) - Method in interface com.hazelcast.spi.impl.NodeEngine
Deserializes an object.
toObject(Object, Class) - Method in interface com.hazelcast.spi.impl.NodeEngine
Deserializes an object.
toObject(Object) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
toObject(Object, Class) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
 
toObjectIfNeeded(Object) - Method in class com.hazelcast.spi.impl.TransactionalDistributedObject
 
toOpControl(Address) - Method in class com.hazelcast.spi.impl.operationservice.CallsPerMember
 
toOperationDesc(Operation) - Static method in class com.hazelcast.internal.diagnostics.OperationDescriptors
 
toPartitionThreadIndex(int) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
TOPIC_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
TOPIC_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
TOPIC_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
TOPIC_EVENT - Static variable in class com.hazelcast.topic.impl.TopicDataSerializerHook
 
TOPIC_OVERLOAD - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
TOPIC_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
TOPIC_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
TOPIC_RB_PREFIX - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferService
Prefix of ringbuffers that are created for topics.
TopicAddMessageListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Subscribes to this topic.
TopicAddMessageListenerCodec.AbstractEventHandler - Class in com.hazelcast.client.impl.protocol.codec
 
TopicAddMessageListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TopicAddMessageListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TopicAddMessageListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.topic
 
TopicAddMessageListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.topic.TopicAddMessageListenerMessageTask
 
TopicConfig - Class in com.hazelcast.config
Contains the configuration for a ITopic.
TopicConfig() - Constructor for class com.hazelcast.config.TopicConfig
Creates a TopicConfig.
TopicConfig(String) - Constructor for class com.hazelcast.config.TopicConfig
Creates a TopicConfig with the given name.
TopicConfig(TopicConfig) - Constructor for class com.hazelcast.config.TopicConfig
Creates a TopicConfig by cloning another TopicConfig.
TopicConfigReadOnly - Class in com.hazelcast.internal.config
Configuration for topic(Read only)
TopicConfigReadOnly(TopicConfig) - Constructor for class com.hazelcast.internal.config.TopicConfigReadOnly
 
TopicDataSerializerHook - Class in com.hazelcast.topic.impl
 
TopicDataSerializerHook() - Constructor for class com.hazelcast.topic.impl.TopicDataSerializerHook
 
TopicMBean - Class in com.hazelcast.internal.jmx
Management bean for ITopic
TopicMBean(ITopic, ManagementService) - Constructor for class com.hazelcast.internal.jmx.TopicMBean
 
topicName - Variable in class com.hazelcast.topic.impl.reliable.MessageRunner
 
TopicOverloadException - Exception in com.hazelcast.topic
A HazelcastException thrown when a publisher wants to write to a topic, but there is not sufficient storage to deal with the event.
TopicOverloadException(String) - Constructor for exception com.hazelcast.topic.TopicOverloadException
Creates a TopicOverloadException.
topicOverloadPolicy - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddReliableTopicConfigCodec.RequestParameters
policy to handle an overloaded topic.
TopicOverloadPolicy - Enum in com.hazelcast.topic
A policy to deal with an overloaded topic; so topic where there is no place to store new messages.
TopicPermission - Class in com.hazelcast.security.permission
 
TopicPermission(String, String...) - Constructor for class com.hazelcast.security.permission.TopicPermission
 
TopicProxy<E> - Class in com.hazelcast.topic.impl
Topic proxy used when global ordering is disabled (nodes get the messages in the order that the messages are published).
TopicProxy(String, NodeEngine, TopicService) - Constructor for class com.hazelcast.topic.impl.TopicProxy
 
TopicProxySupport - Class in com.hazelcast.topic.impl
 
TopicProxySupport(String, NodeEngine, TopicService) - Constructor for class com.hazelcast.topic.impl.TopicProxySupport
 
TopicPublishCodec - Class in com.hazelcast.client.impl.protocol.codec
Publishes the message to all subscribers of this topic
TopicPublishCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TopicPublishCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TopicPublishMessageTask - Class in com.hazelcast.client.impl.protocol.task.topic
 
TopicPublishMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.topic.TopicPublishMessageTask
 
TopicRemoveMessageListenerCodec - Class in com.hazelcast.client.impl.protocol.codec
Stops receiving messages for the given message listener.If the given listener already removed, this method does nothing.
TopicRemoveMessageListenerCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TopicRemoveMessageListenerCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TopicRemoveMessageListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.topic
 
TopicRemoveMessageListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.topic.TopicRemoveMessageListenerMessageTask
 
TopicService - Class in com.hazelcast.topic.impl
 
TopicService() - Constructor for class com.hazelcast.topic.impl.TopicService
 
TOPOLOGY_CHANGED - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
toPrettyString() - Method in class com.hazelcast.memory.MemorySize
Returns a pretty format String representation of this memory size.
toPrettyString(long) - Static method in class com.hazelcast.memory.MemorySize
Utility method to create a pretty format representation of given value in bytes.
toPrettyString(long, MemoryUnit) - Static method in class com.hazelcast.memory.MemorySize
Utility method to create a pretty format representation of given value in given unit.
toRaftEndpoint() - Method in class com.hazelcast.cp.internal.CPMemberInfo
 
toRingbufferConfig(EventJournalConfig, ObjectNamespace) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
Creates a new RingbufferConfig for a ringbuffer that will keep event journal events for a single partition.
toRingbufferConfig(EventJournalConfig, ObjectNamespace) - Method in interface com.hazelcast.internal.journal.EventJournal
Creates a new RingbufferConfig for a ringbuffer that will keep event journal events for a single partition.
toRingbufferConfig(EventJournalConfig, ObjectNamespace) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
 
toSearchControlValue() - Method in enum com.hazelcast.config.security.LdapSearchScope
 
toStorageValue(Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
toStoreValue(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
toString() - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
toString() - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
toString() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
toString() - Method in class com.hazelcast.cache.impl.CacheContext
 
toString() - Method in class com.hazelcast.cache.impl.CacheEntryEventImpl
 
toString() - Method in class com.hazelcast.cache.impl.CacheEntryIterationResult
 
toString() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
 
toString() - Method in class com.hazelcast.cache.impl.CacheKeyIterationResult
 
toString() - Method in class com.hazelcast.cache.impl.CachePartitionEventData
 
toString() - Method in class com.hazelcast.cache.impl.CacheService
 
toString() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
 
toString() - Method in class com.hazelcast.cache.impl.event.AbstractICacheEvent
Returns a String representation of this event.
toString() - Method in class com.hazelcast.cache.impl.event.CachePartitionLostEvent
 
toString() - Method in class com.hazelcast.cache.impl.eviction.CacheClearExpiredRecordsTask
 
toString() - Method in class com.hazelcast.cache.impl.HazelcastServerCachingProvider
 
toString() - Method in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
 
toString(StringBuilder) - Method in class com.hazelcast.cache.impl.operation.CacheClearExpiredOperation
 
toString(StringBuilder) - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperation
 
toString() - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorProxy
 
toString(StringBuilder) - Method in class com.hazelcast.cardinality.impl.operations.AbstractCardinalityEstimatorOperation
 
toString() - Method in class com.hazelcast.client.cache.impl.ClientCacheStatisticsImpl
 
toString() - Method in class com.hazelcast.client.cache.impl.HazelcastClientCachingProvider
 
toString() - Method in class com.hazelcast.client.config.ClientCloudConfig
 
toString() - Method in class com.hazelcast.client.config.ClientConfig
 
toString() - Method in class com.hazelcast.client.config.ClientConnectionStrategyConfig
 
toString() - Method in class com.hazelcast.client.config.ClientFailoverConfig
 
toString() - Method in class com.hazelcast.client.config.ClientFlakeIdGeneratorConfig
 
toString() - Method in class com.hazelcast.client.config.ClientIcmpPingConfig
 
toString() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
toString() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
 
toString() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
toString() - Method in class com.hazelcast.client.config.ClientUserCodeDeploymentConfig
 
toString() - Method in class com.hazelcast.client.config.ConnectionRetryConfig
 
toString() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
toString() - Method in class com.hazelcast.client.config.SocketOptions
 
toString() - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
toString() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
toString() - Method in class com.hazelcast.client.impl.ClientEvent
 
toString() - Method in class com.hazelcast.client.impl.clientside.ClientDynamicClusterConfig
 
toString() - Method in class com.hazelcast.client.impl.clientside.HazelcastClientProxy
 
toString() - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
toString() - Method in class com.hazelcast.client.impl.operations.OperationFactoryWrapper
 
toString() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
 
toString() - Method in class com.hazelcast.client.impl.proxy.ClientCardinalityEstimatorProxy
 
toString() - Method in class com.hazelcast.client.impl.proxy.ClientExecutorServiceProxy
 
toString() - Method in class com.hazelcast.client.impl.proxy.ClientFlakeIdGeneratorProxy
 
toString() - Method in class com.hazelcast.client.impl.proxy.ClientListProxy
 
toString() - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
toString() - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
toString() - Method in class com.hazelcast.client.impl.proxy.ClientPNCounterProxy
 
toString() - Method in class com.hazelcast.client.impl.proxy.ClientQueueProxy
 
toString() - Method in class com.hazelcast.client.impl.proxy.ClientReliableTopicProxy
 
toString() - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
toString() - Method in class com.hazelcast.client.impl.proxy.ClientRingbufferProxy
 
toString() - Method in class com.hazelcast.client.impl.proxy.ClientScheduledExecutorProxy
 
toString() - Method in class com.hazelcast.client.impl.proxy.ClientSetProxy
 
toString() - Method in class com.hazelcast.client.impl.proxy.ClientTopicProxy
 
toString() - Method in class com.hazelcast.client.impl.proxy.txn.xa.XAResourceProxy
 
toString() - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocation
 
toString() - Method in class com.hazelcast.client.impl.spi.impl.listener.ClientRegistrationKey
 
toString() - Method in class com.hazelcast.cluster.Address
 
toString() - Method in class com.hazelcast.cluster.impl.AbstractMember
 
toString() - Method in class com.hazelcast.cluster.impl.VectorClock
 
toString() - Method in class com.hazelcast.cluster.InitialMembershipEvent
 
toString() - Method in class com.hazelcast.cluster.MembershipEvent
 
toString(StringBuilder) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
 
toString() - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
toString() - Method in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxy
 
toString() - Method in class com.hazelcast.collection.ItemEvent
 
toString() - Method in class com.hazelcast.config.AbstractBasicConfig
 
toString() - Method in class com.hazelcast.config.AdvancedNetworkConfig.MemberNetworkingView
 
toString() - Method in class com.hazelcast.config.AdvancedNetworkConfig
 
toString() - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
toString() - Method in class com.hazelcast.config.AttributeConfig
 
toString() - Method in class com.hazelcast.config.CacheConfig
 
toString() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
toString() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
toString() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
toString() - Method in class com.hazelcast.config.CacheSimpleConfig
 
toString() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
toString() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
toString() - Method in class com.hazelcast.config.ClassFilter
 
toString() - Method in class com.hazelcast.config.Config
 
toString() - Method in class com.hazelcast.config.cp.CPSubsystemConfig
 
toString() - Method in class com.hazelcast.config.cp.FencedLockConfig
 
toString() - Method in class com.hazelcast.config.cp.RaftAlgorithmConfig
 
toString() - Method in class com.hazelcast.config.cp.SemaphoreConfig
 
toString() - Method in class com.hazelcast.config.CredentialsFactoryConfig
 
toString() - Method in class com.hazelcast.config.CustomWanPublisherConfig
 
toString() - Method in class com.hazelcast.config.DiscoveryConfig
 
toString() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
toString() - Method in class com.hazelcast.config.DurableExecutorConfig
 
toString() - Method in class com.hazelcast.config.EncryptionAtRestConfig
 
toString() - Method in class com.hazelcast.config.EntryListenerConfig
 
toString() - Method in class com.hazelcast.config.EventJournalConfig
 
toString() - Method in class com.hazelcast.config.EvictionConfig
 
toString() - Method in class com.hazelcast.config.ExecutorConfig
 
toString() - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
toString() - Method in class com.hazelcast.config.GlobalSerializerConfig
 
toString() - Method in class com.hazelcast.config.HotRestartConfig
 
toString() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
 
toString() - Method in class com.hazelcast.config.IcmpFailureDetectorConfig
 
toString() - Method in class com.hazelcast.config.IndexConfig
 
toString() - Method in class com.hazelcast.config.InterfacesConfig
 
toString() - Method in class com.hazelcast.config.ItemListenerConfig
 
toString() - Method in class com.hazelcast.config.JavaKeyStoreSecureStoreConfig
 
toString() - Method in class com.hazelcast.config.JavaSerializationFilterConfig
 
toString() - Method in class com.hazelcast.config.JoinConfig
 
toString() - Method in class com.hazelcast.config.ListConfig
 
toString() - Method in class com.hazelcast.config.ListenerConfig
 
toString() - Method in class com.hazelcast.config.LoginModuleConfig
 
toString() - Method in class com.hazelcast.config.ManagementCenterConfig
 
toString() - Method in class com.hazelcast.config.MapConfig
 
toString() - Method in class com.hazelcast.config.MapStoreConfig
 
toString() - Method in class com.hazelcast.config.MaxSizeConfig
 
toString() - Method in class com.hazelcast.config.MCMutualAuthConfig
 
toString() - Method in class com.hazelcast.config.MemberAddressProviderConfig
 
toString() - Method in class com.hazelcast.config.MemberGroupConfig
 
toString() - Method in class com.hazelcast.config.MemcacheProtocolConfig
 
toString() - Method in class com.hazelcast.config.MergePolicyConfig
 
toString() - Method in class com.hazelcast.config.MerkleTreeConfig
 
toString() - Method in class com.hazelcast.config.MetricsConfig
 
toString() - Method in class com.hazelcast.config.MulticastConfig
 
toString() - Method in class com.hazelcast.config.MultiMapConfig
 
toString() - Method in class com.hazelcast.config.NativeMemoryConfig
 
toString() - Method in class com.hazelcast.config.NearCacheConfig
 
toString() - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
toString() - Method in class com.hazelcast.config.NetworkConfig
 
toString() - Method in class com.hazelcast.config.PartitionGroupConfig
 
toString() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
toString() - Method in class com.hazelcast.config.PermissionConfig
 
toString() - Method in class com.hazelcast.config.PermissionPolicyConfig
 
toString() - Method in class com.hazelcast.config.PredicateConfig
 
toString() - Method in class com.hazelcast.config.QueryCacheConfig
 
toString() - Method in class com.hazelcast.config.QueueConfig
 
toString() - Method in class com.hazelcast.config.QueueStoreConfig
 
toString() - Method in class com.hazelcast.config.ReliableTopicConfig
 
toString() - Method in class com.hazelcast.config.ReplicatedMapConfig
 
toString() - Method in class com.hazelcast.config.RestApiConfig
 
toString() - Method in class com.hazelcast.config.RestServerEndpointConfig
 
toString() - Method in class com.hazelcast.config.RingbufferConfig
 
toString() - Method in class com.hazelcast.config.RingbufferStoreConfig
 
toString() - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
toString() - Method in class com.hazelcast.config.security.CredentialsIdentityConfig
 
toString() - Method in class com.hazelcast.config.security.JaasAuthenticationConfig
 
toString() - Method in class com.hazelcast.config.security.LdapAuthenticationConfig
 
toString() - Method in enum com.hazelcast.config.security.LdapRoleMappingMode
 
toString() - Method in enum com.hazelcast.config.security.LdapSearchScope
 
toString() - Method in class com.hazelcast.config.security.RealmConfig
 
toString() - Method in class com.hazelcast.config.security.TlsAuthenticationConfig
 
toString() - Method in enum com.hazelcast.config.security.TokenEncoding
 
toString() - Method in class com.hazelcast.config.security.TokenIdentityConfig
 
toString() - Method in class com.hazelcast.config.security.UsernamePasswordIdentityConfig
 
toString() - Method in class com.hazelcast.config.SecurityConfig
 
toString() - Method in class com.hazelcast.config.SerializationConfig
 
toString() - Method in class com.hazelcast.config.SerializerConfig
 
toString() - Method in class com.hazelcast.config.ServerSocketEndpointConfig
 
toString() - Method in class com.hazelcast.config.ServiceConfig
 
toString() - Method in class com.hazelcast.config.ServicesConfig
 
toString() - Method in class com.hazelcast.config.SetConfig
 
toString() - Method in class com.hazelcast.config.SocketInterceptorConfig
 
toString() - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
toString() - Method in class com.hazelcast.config.SSLConfig
 
toString() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
toString() - Method in class com.hazelcast.config.TcpIpConfig
 
toString() - Method in class com.hazelcast.config.TopicConfig
 
toString() - Method in class com.hazelcast.config.VaultSecureStoreConfig
 
toString() - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
toString() - Method in class com.hazelcast.config.WanConsumerConfig
 
toString() - Method in class com.hazelcast.config.WanReplicationConfig
 
toString() - Method in class com.hazelcast.config.WanReplicationRef
 
toString() - Method in class com.hazelcast.config.WanSyncConfig
 
toString() - Method in class com.hazelcast.core.DistributedObjectEvent
 
toString() - Method in class com.hazelcast.core.EntryEvent
 
toString() - Method in class com.hazelcast.core.HazelcastJsonValue
Returns unaltered string that was used to create this object.
toString() - Method in class com.hazelcast.core.LifecycleEvent
 
toString() - Method in class com.hazelcast.cp.internal.CPGroupInfo
 
toString() - Method in class com.hazelcast.cp.internal.CPGroupSummary
 
toString() - Method in class com.hazelcast.cp.internal.CPMemberInfo
 
toString() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLong
 
toString() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongSnapshot
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.AbstractAtomicLongOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.AddAndGetOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.CompareAndSetOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.GetAndAddOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.GetAndSetOp
 
toString() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRef
 
toString() - Method in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefSnapshot
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.AbstractAtomicRefOp
 
toString() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.AwaitInvocationKey
 
toString() - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatch
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.AbstractCountDownLatchOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.AwaitOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.CountDownOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.TrySetCountOp
 
toString() - Method in class com.hazelcast.cp.internal.datastructures.lock.Lock
 
toString() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockEndpoint
 
toString() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockInvocationKey
 
toString() - Method in class com.hazelcast.cp.internal.datastructures.lock.LockOwnershipState
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.GetLockOwnershipStateOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.LockOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.TryLockOp
 
toString() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.AcquireInvocationKey
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.AcquirePermitsOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.AvailablePermitsOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.ChangePermitsOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.InitSemaphoreOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.ReleasePermitsOp
 
toString() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.Semaphore
 
toString() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreEndpoint
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.operation.ExpireWaitKeysOp
 
toString() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
toString() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKeyContainer
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.datastructures.spi.operation.DestroyRaftObjectOp
 
toString() - Method in class com.hazelcast.cp.internal.MembershipChangeSchedule.CPGroupMembershipChange
 
toString() - Method in class com.hazelcast.cp.internal.MembershipChangeSchedule
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.operation.ChangeRaftGroupMembershipOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.operation.DefaultRaftReplicateOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.operation.RaftQueryOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.operation.RaftReplicateOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.operation.unsafe.AbstractUnsafeRaftOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.operation.unsafe.UnsafeSnapshotReplicationOp
 
toString() - Method in class com.hazelcast.cp.internal.raft.command.DestroyRaftGroupCmd
 
toString() - Method in class com.hazelcast.cp.internal.raft.impl.command.UpdateRaftGroupMembersCmd
 
toString() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendFailureResponse
 
toString() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendRequest
 
toString() - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendSuccessResponse
 
toString() - Method in class com.hazelcast.cp.internal.raft.impl.dto.InstallSnapshot
 
toString() - Method in class com.hazelcast.cp.internal.raft.impl.dto.PreVoteRequest
 
toString() - Method in class com.hazelcast.cp.internal.raft.impl.dto.PreVoteResponse
 
toString() - Method in class com.hazelcast.cp.internal.raft.impl.dto.TriggerLeaderElection
 
toString() - Method in class com.hazelcast.cp.internal.raft.impl.dto.VoteRequest
 
toString() - Method in class com.hazelcast.cp.internal.raft.impl.dto.VoteResponse
 
toString() - Method in class com.hazelcast.cp.internal.raft.impl.log.LogEntry
 
toString(boolean) - Method in class com.hazelcast.cp.internal.raft.impl.log.SnapshotEntry
 
toString() - Method in class com.hazelcast.cp.internal.raft.impl.log.SnapshotEntry
 
toString() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
toString() - Method in class com.hazelcast.cp.internal.raft.impl.state.FollowerState
 
toString() - Method in class com.hazelcast.cp.internal.raft.impl.state.QueryState
 
toString() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftGroupMembers
 
toString() - Method in class com.hazelcast.cp.internal.raft.impl.task.MembershipChangeTask
 
toString() - Method in class com.hazelcast.cp.internal.RaftEndpointImpl
 
toString() - Method in class com.hazelcast.cp.internal.RaftGroupId
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.raftop.metadata.AddCPMemberOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.raftop.metadata.CompleteDestroyRaftGroupsOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.raftop.metadata.CompleteRaftGroupMembershipChangesOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.raftop.metadata.CreateRaftGroupOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.raftop.metadata.CreateRaftNodeOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.raftop.metadata.DestroyRaftNodesOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.raftop.metadata.ForceDestroyRaftGroupOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetActiveRaftGroupByNameOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetRaftGroupOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.raftop.metadata.InitMetadataRaftGroupOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.raftop.metadata.PublishActiveCPMembersOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.raftop.metadata.RaftServicePreJoinOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.raftop.metadata.RemoveCPMemberOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.raftop.metadata.TriggerDestroyRaftGroupOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.raftop.snapshot.RestoreSnapshotOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.RaftOp
 
toString() - Method in class com.hazelcast.cp.internal.RaftOp
 
toString() - Method in class com.hazelcast.cp.internal.session.CPSessionInfo
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.session.operation.CloseSessionOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.session.operation.CreateSessionOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.session.operation.ExpireSessionsOp
 
toString(StringBuilder) - Method in class com.hazelcast.cp.internal.session.operation.HeartbeatSessionOp
 
toString() - Method in class com.hazelcast.cp.internal.session.SessionResponse
 
toString() - Method in class com.hazelcast.cp.internal.util.PartitionSpecificRunnableAdaptor
 
toString() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
toString() - Method in class com.hazelcast.executor.impl.RunnableAdapter
 
toString() - Method in class com.hazelcast.hotrestart.BackupTaskStatus
 
toString() - Method in class com.hazelcast.instance.BuildInfo
 
toString() - Method in class com.hazelcast.instance.EndpointQualifier
 
toString() - Method in class com.hazelcast.instance.impl.HazelcastInstanceImpl
 
toString() - Method in class com.hazelcast.instance.impl.HazelcastInstanceProxy
 
toString() - Method in class com.hazelcast.instance.impl.Node
 
toString() - Method in class com.hazelcast.instance.JetBuildInfo
 
toString() - Method in class com.hazelcast.internal.ascii.AbstractTextCommand
 
toString() - Method in class com.hazelcast.internal.ascii.memcache.DeleteCommand
 
toString() - Method in class com.hazelcast.internal.ascii.memcache.ErrorCommand
 
toString() - Method in class com.hazelcast.internal.ascii.memcache.GetCommand
 
toString() - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
 
toString() - Method in class com.hazelcast.internal.ascii.memcache.SetCommand
 
toString() - Method in class com.hazelcast.internal.ascii.memcache.SimpleCommand
 
toString() - Method in class com.hazelcast.internal.ascii.memcache.StatsCommand
 
toString() - Method in class com.hazelcast.internal.ascii.NoOpCommand
 
toString() - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
 
toString() - Method in enum com.hazelcast.internal.ascii.rest.HttpPostCommandProcessor.ResponseType
 
toString() - Method in class com.hazelcast.internal.ascii.rest.RestValue
 
toString() - Method in enum com.hazelcast.internal.cluster.fd.ClusterFailureDetectorType
 
toString() - Method in class com.hazelcast.internal.cluster.impl.BindMessage
 
toString() - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
toString() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateChange
 
toString() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateManager
 
toString() - Method in class com.hazelcast.internal.cluster.impl.ExtendedBindMessage
 
toString() - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
 
toString() - Method in class com.hazelcast.internal.cluster.impl.JoinRequest
 
toString() - Method in class com.hazelcast.internal.cluster.impl.MembersView
 
toString() - Method in class com.hazelcast.internal.cluster.impl.MembersViewMetadata
 
toString(StringBuilder) - Method in class com.hazelcast.internal.cluster.impl.operations.FinalizeJoinOp
 
toString(StringBuilder) - Method in class com.hazelcast.internal.cluster.impl.operations.JoinRequestOp
 
toString(StringBuilder) - Method in class com.hazelcast.internal.cluster.impl.operations.MasterResponseOp
 
toString(StringBuilder) - Method in class com.hazelcast.internal.cluster.impl.operations.MembersUpdateOp
 
toString(StringBuilder) - Method in class com.hazelcast.internal.cluster.impl.operations.OnJoinOp
 
toString(StringBuilder) - Method in class com.hazelcast.internal.cluster.impl.operations.WhoisMasterOp
 
toString() - Method in class com.hazelcast.internal.cluster.impl.SplitBrainJoinMessage
 
toString() - Method in class com.hazelcast.internal.cluster.MemberInfo
 
toString() - Method in class com.hazelcast.internal.config.PredicateConfigReadOnly
 
toString() - Method in class com.hazelcast.internal.crdt.CRDTReplicationMigrationService
 
toString(StringBuilder) - Method in class com.hazelcast.internal.crdt.pncounter.operations.AbstractPNCounterOperation
 
toString() - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterProxy
 
toString() - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
toString() - Method in class com.hazelcast.internal.journal.DeserializingEntry
 
toString() - Method in class com.hazelcast.internal.json.JsonValue
Returns the JSON string for this value in its minimal form, without any additional whitespace.
toString(WriterConfig) - Method in class com.hazelcast.internal.json.JsonValue
Returns the JSON string for this value using the given formatting.
toString() - Method in class com.hazelcast.internal.json.Location
 
toString() - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
toString() - Method in class com.hazelcast.internal.locksupport.LockWaitNotifyKey
 
toString(StringBuilder) - Method in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
toString() - Method in class com.hazelcast.internal.longregister.client.ClientLongRegisterProxy
 
toString() - Method in class com.hazelcast.internal.longregister.LongRegisterProxy
 
toString(StringBuilder) - Method in class com.hazelcast.internal.longregister.operations.AbstractLongRegisterOperation
 
toString() - Method in class com.hazelcast.internal.management.TimedMemberState
 
toString() - Method in class com.hazelcast.internal.memory.DefaultGarbageCollectorStats
 
toString() - Method in class com.hazelcast.internal.memory.DefaultMemoryStats
 
toString() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.BatchNearCacheInvalidation
 
toString() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidation
 
toString() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingHandler
 
toString() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingTask
 
toString() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.SingleNearCacheInvalidation
 
toString() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.StaleReadDetectorImpl
 
toString() - Method in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
toString() - Method in class com.hazelcast.internal.nearcache.impl.record.NearCacheDataRecord
 
toString() - Method in class com.hazelcast.internal.nearcache.impl.record.NearCacheObjectRecord
 
toString() - Method in class com.hazelcast.internal.networking.ChannelOption
 
toString() - Method in class com.hazelcast.internal.networking.nio.NioChannel
 
toString() - Method in class com.hazelcast.internal.networking.nio.NioInboundPipeline
 
toString() - Method in class com.hazelcast.internal.networking.nio.NioOutboundPipeline
 
toString() - Method in class com.hazelcast.internal.networking.nio.NioThread
 
toString() - Method in class com.hazelcast.internal.networking.ServerSocketRegistry
 
toString() - Method in class com.hazelcast.internal.nio.Packet
 
toString() - Method in class com.hazelcast.internal.nio.tcp.ClientViewUnifiedEndpointManager
 
toString() - Method in class com.hazelcast.internal.nio.tcp.MemberViewUnifiedEndpointManager
 
toString() - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
toString() - Method in class com.hazelcast.internal.nio.tcp.TcpIpEndpointManager
 
toString() - Method in class com.hazelcast.internal.nio.tcp.TextViewUnifiedEndpointManager
 
toString() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionImpl
 
toString() - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
toString() - Method in class com.hazelcast.internal.partition.impl.MigrationStats
 
toString() - Method in class com.hazelcast.internal.partition.impl.ReplicaFragmentSyncInfo
 
toString() - Method in class com.hazelcast.internal.partition.MigrationInfo
 
toString() - Method in class com.hazelcast.internal.partition.MigrationStateImpl
 
toString() - Method in class com.hazelcast.internal.partition.NonFragmentedServiceNamespace
 
toString(StringBuilder) - Method in class com.hazelcast.internal.partition.operation.PartitionBackupReplicaAntiEntropyOperation
 
toString(StringBuilder) - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncResponse
 
toString() - Method in class com.hazelcast.internal.partition.PartitionLostEventImpl
 
toString() - Method in class com.hazelcast.internal.partition.PartitionReplica
 
toString() - Method in class com.hazelcast.internal.partition.PartitionRuntimeState
 
toString() - Method in class com.hazelcast.internal.partition.PartitionTableView
 
toString() - Method in class com.hazelcast.internal.partition.ReplicaMigrationEventImpl
 
toString() - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
 
toString() - Method in class com.hazelcast.internal.serialization.impl.FieldDefinitionImpl
 
toString() - Method in class com.hazelcast.internal.serialization.impl.HeapData
 
toString() - Method in class com.hazelcast.internal.util.AddressUtil.AddressHolder
 
toString() - Method in class com.hazelcast.internal.util.AddressUtil.AddressMatcher
 
toString() - Method in class com.hazelcast.internal.util.BiTuple
 
toString() - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
 
toString() - Method in class com.hazelcast.internal.util.collection.IntHashSet
 
toString() - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
 
toString() - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
 
toString() - Method in class com.hazelcast.internal.util.collection.LongHashSet
toString() - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap.SimpleEntry
 
toString() - Method in class com.hazelcast.internal.util.counters.MwCounter
 
toString(Throwable) - Static method in class com.hazelcast.internal.util.ExceptionUtil
Converts a Throwable stacktrace to a String.
toString() - Method in class com.hazelcast.internal.util.executor.CompletableFutureTask
 
toString() - Method in class com.hazelcast.internal.util.executor.NamedThreadPoolExecutor
 
toString() - Method in class com.hazelcast.internal.util.ItemCounter
 
toString() - Method in class com.hazelcast.internal.util.LockGuard
 
toString() - Method in class com.hazelcast.internal.util.MutableLong
 
toString() - Method in class com.hazelcast.internal.util.SampleableConcurrentHashMap.SamplingEntry
 
toString() - Method in class com.hazelcast.internal.util.scheduler.ScheduledEntry
 
toString() - Method in class com.hazelcast.internal.util.scheduler.SecondsBasedEntryTaskScheduler
 
toString() - Method in class com.hazelcast.internal.util.StateMachine
 
toString() - Method in class com.hazelcast.internal.util.TriTuple
 
toString() - Method in class com.hazelcast.internal.yaml.YamlMappingImpl
 
toString() - Method in class com.hazelcast.internal.yaml.YamlScalarImpl
 
toString() - Method in class com.hazelcast.json.internal.JsonPattern
 
toString() - Method in class com.hazelcast.json.internal.JsonSchemaNameValue
 
toString() - Method in class com.hazelcast.json.internal.JsonSchemaStructNode
 
toString() - Method in class com.hazelcast.json.internal.JsonSchemaTerminalNode
 
toString() - Method in class com.hazelcast.map.AbstractIMapEvent
Returns a String representation of this event.
toString() - Method in class com.hazelcast.map.EventLostEvent
 
toString() - Method in class com.hazelcast.map.impl.EntryEventFilter
 
toString() - Method in class com.hazelcast.map.impl.event.DefaultEntryEventFilteringStrategy
 
toString() - Method in class com.hazelcast.map.impl.event.EntryEventData
 
toString() - Method in class com.hazelcast.map.impl.event.MapEventData
 
toString() - Method in class com.hazelcast.map.impl.event.MapPartitionEventData
 
toString() - Method in class com.hazelcast.map.impl.event.QueryCacheNaturalFilteringStrategy
 
toString() - Method in class com.hazelcast.map.impl.EventListenerFilter
 
toString() - Method in class com.hazelcast.map.impl.eviction.EvictorImpl
 
toString() - Method in class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
 
toString() - Method in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
 
toString() - Method in class com.hazelcast.map.impl.LazyMapEntry
 
toString() - Method in class com.hazelcast.map.impl.MapPartitionLostEventFilter
 
toString() - Method in class com.hazelcast.map.impl.mapstore.writebehind.StoreWorker
 
toString() - Method in class com.hazelcast.map.impl.MapStoreWrapper
 
toString() - Method in class com.hazelcast.map.impl.nearcache.invalidation.UuidFilter
 
toString(StringBuilder) - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperation
 
toString(StringBuilder) - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
 
toString(StringBuilder) - Method in class com.hazelcast.map.impl.operation.MapClearExpiredOperation
 
toString(StringBuilder) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
 
toString(StringBuilder) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperation
 
toString(StringBuilder) - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
 
toString() - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
toString() - Method in class com.hazelcast.map.impl.query.QueryEventFilter
 
toString() - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
 
toString() - Method in class com.hazelcast.map.impl.querycache.event.BatchEventData
 
toString() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
toString() - Method in class com.hazelcast.map.impl.querycache.event.LocalCacheWideEventData
 
toString() - Method in class com.hazelcast.map.impl.querycache.event.LocalEntryEventData
 
toString() - Method in class com.hazelcast.map.impl.record.RecordInfo
 
toString() - Method in class com.hazelcast.map.impl.record.RecordReplicationInfo
 
toString() - Method in class com.hazelcast.map.impl.recordstore.LazyEntryViewFromRecord
 
toString() - Method in class com.hazelcast.map.impl.SimpleEntryView
 
toString() - Method in class com.hazelcast.map.impl.tx.MapTransactionLogRecord
 
toString() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
toString(StringBuilder) - Method in class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
 
toString(StringBuilder) - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
 
toString() - Method in class com.hazelcast.map.impl.wan.WanMapEntryView
 
toString() - Method in class com.hazelcast.map.MapEvent
 
toString() - Method in class com.hazelcast.map.MapPartitionLostEvent
 
toString() - Method in class com.hazelcast.memory.MemorySize
 
toString() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
toString() - Method in class com.hazelcast.monitor.impl.HotRestartStateImpl
 
toString() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
 
toString() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
 
toString() - Method in class com.hazelcast.monitor.impl.LocalFlakeIdGeneratorStatsImpl
 
toString() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
 
toString() - Method in class com.hazelcast.monitor.impl.LocalIndexStatsImpl
 
toString() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
toString() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
 
toString() - Method in class com.hazelcast.monitor.impl.LocalOperationStatsImpl
 
toString() - Method in class com.hazelcast.monitor.impl.LocalPNCounterStatsImpl
 
toString() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
toString() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
toString() - Method in class com.hazelcast.monitor.impl.LocalTopicStatsImpl
 
toString() - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
 
toString() - Method in class com.hazelcast.monitor.impl.LocalWanStatsImpl
 
toString() - Method in class com.hazelcast.monitor.impl.MemberPartitionStateImpl
 
toString() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
 
toString() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
 
toString() - Method in class com.hazelcast.monitor.impl.NodeStateImpl
 
toString() - Method in class com.hazelcast.monitor.impl.OnDemandIndexStats
 
toString() - Method in class com.hazelcast.monitor.impl.WanSyncStateImpl
 
toString() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
toString(StringBuilder) - Method in class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
 
toString() - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
 
toString() - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
 
toString() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
toString() - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
toString() - Method in class com.hazelcast.partition.PartitionAwareKey
 
toString() - Method in class com.hazelcast.query.impl.CompositeValue
 
toString() - Method in class com.hazelcast.query.impl.getters.FieldGetter
 
toString() - Method in class com.hazelcast.query.impl.getters.MethodGetter
 
toString() - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
toString() - Method in class com.hazelcast.query.impl.predicates.AndPredicate
 
toString() - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
 
toString() - Method in class com.hazelcast.query.impl.predicates.BoundedRangePredicate
 
toString() - Method in class com.hazelcast.query.impl.predicates.CompositeEqualPredicate
 
toString() - Method in class com.hazelcast.query.impl.predicates.CompositeRangePredicate
 
toString() - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
 
toString() - Method in class com.hazelcast.query.impl.predicates.FalsePredicate
 
toString() - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
 
toString() - Method in class com.hazelcast.query.impl.predicates.ILikePredicate
 
toString() - Method in class com.hazelcast.query.impl.predicates.InPredicate
 
toString() - Method in class com.hazelcast.query.impl.predicates.InstanceOfPredicate
 
toString() - Method in class com.hazelcast.query.impl.predicates.LikePredicate
 
toString() - Method in class com.hazelcast.query.impl.predicates.NotEqualPredicate
 
toString() - Method in class com.hazelcast.query.impl.predicates.NotPredicate
 
toString() - Method in class com.hazelcast.query.impl.predicates.OrPredicate
 
toString() - Method in class com.hazelcast.query.impl.predicates.PartitionPredicateImpl
 
toString() - Method in class com.hazelcast.query.impl.predicates.RegexPredicate
 
toString() - Method in class com.hazelcast.query.impl.predicates.SkipIndexPredicate
 
toString() - Method in class com.hazelcast.query.impl.predicates.SqlPredicate
 
toString() - Method in class com.hazelcast.query.impl.predicates.TruePredicate
 
toString(StringBuilder) - Method in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
 
toString() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
toString() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
toString() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
toString() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
toString(StringBuilder) - Method in class com.hazelcast.ringbuffer.impl.operations.AbstractRingBufferOperation
 
toString() - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
 
toString() - Method in class com.hazelcast.ringbuffer.impl.RingbufferWaitNotifyKey
 
toString(StringBuilder) - Method in class com.hazelcast.scheduledexecutor.impl.operations.AbstractSchedulerOperation
 
toString() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledRunnableAdapter
 
toString() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskDescriptor
 
toString() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
 
toString() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskResult
 
toString() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskStatisticsImpl
 
toString() - Method in class com.hazelcast.scheduledexecutor.impl.TaskDefinition
 
toString() - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
toString() - Method in class com.hazelcast.security.permission.AllPermissions
 
toString() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
toString() - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
toString() - Method in class com.hazelcast.security.SimpleTokenCredentials
 
toString() - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
toString() - Method in class com.hazelcast.spi.impl.AbstractDistributedObject
 
toString() - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture.ExceptionalResult
 
toString() - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
toString() - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
toString() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventEnvelope
 
toString() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventProcessor
 
toString() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
 
toString() - Method in class com.hazelcast.spi.impl.eventservice.impl.TrueEventFilter
 
toString() - Method in class com.hazelcast.spi.impl.executionservice.impl.DelegateAndSkipOnConcurrentExecutionDecorator
 
toString() - Method in class com.hazelcast.spi.impl.merge.AbstractCollectionMergingValueImpl
 
toString() - Method in class com.hazelcast.spi.impl.merge.AbstractMergingEntryImpl
 
toString() - Method in class com.hazelcast.spi.impl.merge.AbstractMergingValueImpl
 
toString() - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
toString() - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
toString() - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
toString() - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
toString() - Method in class com.hazelcast.spi.impl.merge.RingbufferMergingValueImpl
 
toString() - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationExecutorImpl
 
toString() - Method in class com.hazelcast.spi.impl.operationparker.impl.OperationParkerImpl
 
toString(StringBuilder) - Method in class com.hazelcast.spi.impl.operationservice.AbstractNamedOperation
 
toString() - Method in class com.hazelcast.spi.impl.operationservice.impl.Invocation
 
toString(StringBuilder) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
 
toString(StringBuilder) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation
 
toString() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.BackupAckResponse
 
toString() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.CallTimeoutResponse
 
toString() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.ErrorResponse
 
toString() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.NormalResponse
 
toString(StringBuilder) - Method in class com.hazelcast.spi.impl.operationservice.Operation
A template method allows for additional information to be passed into the Operation.toString() method.
toString() - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
toString() - Method in class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectEventPacket
 
toString() - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyInfo
 
toString() - Method in class com.hazelcast.spi.impl.servicemanager.ServiceInfo
 
toString() - Method in class com.hazelcast.spi.partition.PartitionMigrationEvent
 
toString() - Method in class com.hazelcast.spi.partition.PartitionReplicationEvent
 
toString() - Method in class com.hazelcast.spi.properties.HazelcastProperty
 
toString() - Method in class com.hazelcast.splitbrainprotection.impl.SplitBrainProtectionImpl
 
toString() - Method in class com.hazelcast.splitbrainprotection.SplitBrainProtectionEvent
 
toString() - Method in class com.hazelcast.topic.impl.reliable.ReliableMessageListenerAdapter
 
toString() - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
toString() - Method in class com.hazelcast.transaction.impl.xa.SerializableXID
 
toString() - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
 
toString() - Method in class com.hazelcast.transaction.TransactionOptions
 
toString() - Method in class com.hazelcast.version.MemberVersion
 
toString() - Method in class com.hazelcast.version.Version
 
toSystemCurrentTimeMillis(long) - Method in class com.hazelcast.internal.util.Clock.ClockImpl
This method converts a given custom clock millisecond offset to underlying system's millisecond offset.
toSystemCurrentTimeMillis(long) - Static method in class com.hazelcast.internal.util.Clock
Converts from configured clock implementation offset to JVM time offset
total() - Method in class com.hazelcast.internal.util.ItemCounter
Returns the total counts.
total() - Method in class com.hazelcast.monitor.impl.EmptyLocalReplicatedMapStats
 
total() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
total() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
 
total() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
 
total() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total number of total operations
totalFramesPending() - Method in class com.hazelcast.internal.networking.nio.NioOutboundPipeline
 
totalIdleTimeNanos - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromAddressCodec.ResponseParameters
TODO DOC
totalIdleTimeNanos - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromPartitionCodec.ResponseParameters
TODO DOC
totalInvocations - Variable in class com.hazelcast.internal.management.dto.SlowOperationDTO
 
TotalOrderedTopicProxy<E> - Class in com.hazelcast.topic.impl
Topic proxy used when global ordering is enabled (all nodes listening to the same topic get their messages in the same order).
TotalOrderedTopicProxy(String, NodeEngine, TopicService) - Constructor for class com.hazelcast.topic.impl.TotalOrderedTopicProxy
 
totalPhysicalMemory() - Static method in class com.hazelcast.internal.memory.MemoryStatsSupport
Returns the total available physical memory on the system in bytes or -1 if not available.
totalRuns - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromAddressCodec.ResponseParameters
TODO DOC
totalRuns - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromPartitionCodec.ResponseParameters
TODO DOC
totalRunTimeNanos - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromAddressCodec.ResponseParameters
TODO DOC
totalRunTimeNanos - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorGetStatsFromPartitionCodec.ResponseParameters
TODO DOC
totalSize() - Method in class com.hazelcast.internal.serialization.impl.HeapData
 
totalSize() - Method in interface com.hazelcast.nio.serialization.Data
Returns the total size of Data in bytes.
totalSwapSpace() - Static method in class com.hazelcast.internal.memory.MemoryStatsSupport
Returns the total amount of swap space in bytes or -1 if not available.
totalValidWaitingOperationCount() - Method in class com.hazelcast.spi.impl.operationparker.impl.WaitSet
 
touch(File) - Static method in class com.hazelcast.internal.nio.IOUtil
Simulates a Linux touch command, by setting the last modified time of given file.
TouchCommand - Class in com.hazelcast.internal.ascii.memcache
 
TouchCommand(TextCommandConstants.TextCommandType, String, int, boolean) - Constructor for class com.hazelcast.internal.ascii.memcache.TouchCommand
 
TouchCommandParser - Class in com.hazelcast.internal.ascii.memcache
 
TouchCommandParser(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.internal.ascii.memcache.TouchCommandParser
 
TouchCommandProcessor - Class in com.hazelcast.internal.ascii.memcache
 
TouchCommandProcessor(TextCommandServiceImpl) - Constructor for class com.hazelcast.internal.ascii.memcache.TouchCommandProcessor
 
TOUCHED - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
 
toUrn() - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
 
toUrn() - Method in class com.hazelcast.scheduledexecutor.ScheduledTaskHandler
Returns the String representation of the handler.
toUserFriendlyString(String) - Static method in class com.hazelcast.internal.nio.Protocols
 
toValue(Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
toValue(Object) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
trackLoading(boolean, Throwable) - Method in class com.hazelcast.map.impl.MapKeyLoader
Advances the state of this map key loader and sets the MapKeyLoader.keyLoadFinished result if the lastBatch is true.
TRANSACTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
Transaction - Interface in com.hazelcast.transaction.impl
 
Transaction.State - Enum in com.hazelcast.transaction.impl
 
TRANSACTION_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
TRANSACTION_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
TRANSACTION_NOT_ACTIVE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
TRANSACTION_ROLLBACK - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
TRANSACTION_TIMED_OUT - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
TransactionAccessor - Class in com.hazelcast.transaction.impl.xa
 
TransactionalDistributedObject<S extends RemoteService> - Class in com.hazelcast.spi.impl
To centralize de-serialization for transactional proxies
TransactionalDistributedObject(NodeEngine, S, Transaction) - Constructor for class com.hazelcast.spi.impl.TransactionalDistributedObject
 
TransactionalList<E> - Interface in com.hazelcast.transaction
Transactional implementation of IList.
TransactionalListAddCodec - Class in com.hazelcast.client.impl.protocol.codec
Adds a new item to the transactional list.
TransactionalListAddCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalListAddCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalListAddMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionallist
 
TransactionalListAddMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListAddMessageTask
 
TransactionalListProxy<E> - Class in com.hazelcast.collection.impl.txnlist
 
TransactionalListProxy(String, Transaction, NodeEngine, ListService) - Constructor for class com.hazelcast.collection.impl.txnlist.TransactionalListProxy
 
TransactionalListRemoveCodec - Class in com.hazelcast.client.impl.protocol.codec
Remove item from the transactional list
TransactionalListRemoveCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalListRemoveCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalListRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionallist
 
TransactionalListRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListRemoveMessageTask
 
TransactionalListSizeCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the size of the list
TransactionalListSizeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalListSizeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalListSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionallist
 
TransactionalListSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListSizeMessageTask
 
TransactionalMap<K,V> - Interface in com.hazelcast.transaction
Transactional implementation of BaseMap.
TransactionalMapContainsKeyCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns true if this map contains an entry for the specified key.
TransactionalMapContainsKeyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapContainsKeyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapContainsKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmap
 
TransactionalMapContainsKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapContainsKeyMessageTask
 
TransactionalMapContainsValueCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns true if this map contains an entry for the specified value.
TransactionalMapContainsValueCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapContainsValueCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapDataStructureAdapter<K,V> - Class in com.hazelcast.internal.adapter
 
TransactionalMapDataStructureAdapter(HazelcastInstance, String) - Constructor for class com.hazelcast.internal.adapter.TransactionalMapDataStructureAdapter
 
TransactionalMapDeleteCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the mapping for a key from this map if it is present.
TransactionalMapDeleteCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapDeleteCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapDeleteMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmap
 
TransactionalMapDeleteMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapDeleteMessageTask
 
TransactionalMapGetCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the value for the specified key, or null if this map does not contain this key.
TransactionalMapGetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapGetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapGetForUpdateCodec - Class in com.hazelcast.client.impl.protocol.codec
Locks the key and then gets and returns the value to which the specified key is mapped.
TransactionalMapGetForUpdateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapGetForUpdateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapGetForUpdateMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmap
 
TransactionalMapGetForUpdateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetForUpdateMessageTask
 
TransactionalMapGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmap
 
TransactionalMapGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetMessageTask
 
TransactionalMapIsEmptyCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns true if this map contains no entries.
TransactionalMapIsEmptyCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapIsEmptyCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapIsEmptyMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmap
 
TransactionalMapIsEmptyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapIsEmptyMessageTask
 
TransactionalMapKeySetCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns a set clone of the keys contained in this map.
TransactionalMapKeySetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapKeySetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapKeySetMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmap
 
TransactionalMapKeySetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetMessageTask
 
TransactionalMapKeySetWithPredicateCodec - Class in com.hazelcast.client.impl.protocol.codec
Queries the map based on the specified predicate and returns the keys of matching entries.
TransactionalMapKeySetWithPredicateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapKeySetWithPredicateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapKeySetWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmap
 
TransactionalMapKeySetWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetWithPredicateMessageTask
 
TransactionalMapProxy - Class in com.hazelcast.map.impl.tx
Proxy implementation of TransactionalMap interface.
TransactionalMapProxy(String, MapService, NodeEngine, Transaction) - Constructor for class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
TransactionalMapProxySupport - Class in com.hazelcast.map.impl.tx
Base class contains proxy helper methods for TransactionalMapProxy
TransactionalMapPutCodec - Class in com.hazelcast.client.impl.protocol.codec
Associates the specified value with the specified key in this map.
TransactionalMapPutCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapPutCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapPutIfAbsentCodec - Class in com.hazelcast.client.impl.protocol.codec
If the specified key is not already associated with a value, associate it with the given value.
TransactionalMapPutIfAbsentCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapPutIfAbsentCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapPutIfAbsentMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmap
 
TransactionalMapPutIfAbsentMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutIfAbsentMessageTask
 
TransactionalMapPutMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmap
 
TransactionalMapPutMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutMessageTask
 
TransactionalMapRemoveCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the mapping for a key from this map if it is present.
TransactionalMapRemoveCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapRemoveCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapRemoveIfSameCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the entry for a key only if currently mapped to a given value.
TransactionalMapRemoveIfSameCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapRemoveIfSameCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapRemoveIfSameMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmap
 
TransactionalMapRemoveIfSameMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveIfSameMessageTask
 
TransactionalMapRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmap
 
TransactionalMapRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveMessageTask
 
TransactionalMapReplaceCodec - Class in com.hazelcast.client.impl.protocol.codec
Replaces the entry for a key only if it is currently mapped to some value.
TransactionalMapReplaceCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapReplaceCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapReplaceIfSameCodec - Class in com.hazelcast.client.impl.protocol.codec
Replaces the entry for a key only if currently mapped to a given value.
TransactionalMapReplaceIfSameCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapReplaceIfSameCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapReplaceIfSameMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmap
 
TransactionalMapReplaceIfSameMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceIfSameMessageTask
 
TransactionalMapReplaceMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmap
 
TransactionalMapReplaceMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceMessageTask
 
TransactionalMapSetCodec - Class in com.hazelcast.client.impl.protocol.codec
Associates the specified value with the specified key in this map.
TransactionalMapSetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapSetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmap
 
TransactionalMapSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSetMessageTask
 
TransactionalMapSizeCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the number of entries in this map.
TransactionalMapSizeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapSizeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmap
 
TransactionalMapSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSizeMessageTask
 
TransactionalMapValuesCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns a collection clone of the values contained in this map.
TransactionalMapValuesCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapValuesCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapValuesMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmap
 
TransactionalMapValuesMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesMessageTask
 
TransactionalMapValuesWithPredicateCodec - Class in com.hazelcast.client.impl.protocol.codec
Queries the map based on the specified predicate and returns the values of matching entries.Specified predicate runs on all members in parallel.
TransactionalMapValuesWithPredicateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapValuesWithPredicateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMapValuesWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmap
 
TransactionalMapValuesWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesWithPredicateMessageTask
 
TransactionalMessageTask - Interface in com.hazelcast.client.impl.protocol.task
Marker interface for txn tasks
TransactionalMultiMap<K,V> - Interface in com.hazelcast.transaction
Transactional implementation of BaseMultiMap.
TransactionalMultiMapGetCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the collection of values associated with the key.
TransactionalMultiMapGetCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMultiMapGetCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMultiMapGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmultimap
 
TransactionalMultiMapGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapGetMessageTask
 
TransactionalMultiMapProxy<K,V> - Class in com.hazelcast.multimap.impl.txn
 
TransactionalMultiMapProxy(NodeEngine, MultiMapService, String, Transaction) - Constructor for class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
 
TransactionalMultiMapProxySupport<K,V> - Class in com.hazelcast.multimap.impl.txn
 
TransactionalMultiMapPutCodec - Class in com.hazelcast.client.impl.protocol.codec
Stores a key-value pair in the multimap.
TransactionalMultiMapPutCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMultiMapPutCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMultiMapPutMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmultimap
 
TransactionalMultiMapPutMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapPutMessageTask
 
TransactionalMultiMapRemoveCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes the given key value pair from the multimap.
TransactionalMultiMapRemoveCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMultiMapRemoveCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMultiMapRemoveEntryCodec - Class in com.hazelcast.client.impl.protocol.codec
Removes all the entries associated with the given key.
TransactionalMultiMapRemoveEntryCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMultiMapRemoveEntryCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMultiMapRemoveEntryMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmultimap
 
TransactionalMultiMapRemoveEntryMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveEntryMessageTask
 
TransactionalMultiMapRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmultimap
 
TransactionalMultiMapRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveMessageTask
 
TransactionalMultiMapSizeCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the number of key-value pairs in the multimap.
TransactionalMultiMapSizeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMultiMapSizeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMultiMapSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmultimap
 
TransactionalMultiMapSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapSizeMessageTask
 
TransactionalMultiMapValueCountCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the number of values matching the given key in the multimap.
TransactionalMultiMapValueCountCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMultiMapValueCountCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalMultiMapValueCountMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalmultimap
 
TransactionalMultiMapValueCountMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapValueCountMessageTask
 
TransactionalObject - Interface in com.hazelcast.transaction
Marker interface for all transactional distributed objects.
TransactionalObjectKey - Class in com.hazelcast.transaction.impl
 
TransactionalObjectKey(String, String) - Constructor for class com.hazelcast.transaction.impl.TransactionalObjectKey
 
TransactionalQueue<E> - Interface in com.hazelcast.transaction
Transactional implementation of BaseQueue.
TransactionalQueueOfferCodec - Class in com.hazelcast.client.impl.protocol.codec
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available.
TransactionalQueueOfferCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalQueueOfferCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalQueueOfferMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalqueue
 
TransactionalQueueOfferMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueOfferMessageTask
 
TransactionalQueuePeekCodec - Class in com.hazelcast.client.impl.protocol.codec
Retrieves, but does not remove, the head of this queue, or returns null if this queue is empty.
TransactionalQueuePeekCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalQueuePeekCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalQueuePeekMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalqueue
 
TransactionalQueuePeekMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePeekMessageTask
 
TransactionalQueuePollCodec - Class in com.hazelcast.client.impl.protocol.codec
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
TransactionalQueuePollCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalQueuePollCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalQueuePollMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalqueue
 
TransactionalQueuePollMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePollMessageTask
 
TransactionalQueueProxy<E> - Class in com.hazelcast.collection.impl.txnqueue
Provides proxy for the Transactional Queue.
TransactionalQueueProxy(NodeEngine, QueueService, String, Transaction) - Constructor for class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxy
 
TransactionalQueueProxySupport<E> - Class in com.hazelcast.collection.impl.txnqueue
Provides support for proxy of the Transactional Queue.
TransactionalQueueSizeCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the number of elements in this collection.If this collection contains more than Integer.MAX_VALUE elements, returns Integer.MAX_VALUE.
TransactionalQueueSizeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalQueueSizeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalQueueSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalqueue
 
TransactionalQueueSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueSizeMessageTask
 
TransactionalQueueTakeCodec - Class in com.hazelcast.client.impl.protocol.codec
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
TransactionalQueueTakeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalQueueTakeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalQueueTakeMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalqueue
 
TransactionalQueueTakeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueTakeMessageTask
 
TransactionalService - Interface in com.hazelcast.internal.services
An interface that can be implemented by SPI services that want to deal with transactions.
transactionalService - Variable in class com.hazelcast.map.impl.MapService
 
TransactionalSet<E> - Interface in com.hazelcast.transaction
Transactional implementation of ISet.
TransactionalSetAddCodec - Class in com.hazelcast.client.impl.protocol.codec
Add new item to transactional set.
TransactionalSetAddCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalSetAddCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalSetAddMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalset
 
TransactionalSetAddMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetAddMessageTask
 
TransactionalSetProxy<E> - Class in com.hazelcast.collection.impl.txnset
 
TransactionalSetProxy(String, Transaction, NodeEngine, SetService) - Constructor for class com.hazelcast.collection.impl.txnset.TransactionalSetProxy
 
TransactionalSetRemoveCodec - Class in com.hazelcast.client.impl.protocol.codec
Remove item from transactional set.
TransactionalSetRemoveCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalSetRemoveCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalSetRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalset
 
TransactionalSetRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetRemoveMessageTask
 
TransactionalSetSizeCodec - Class in com.hazelcast.client.impl.protocol.codec
Returns the size of the set.
TransactionalSetSizeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalSetSizeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionalSetSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.transactionalset
 
TransactionalSetSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetSizeMessageTask
 
TransactionalTask<T> - Interface in com.hazelcast.transaction
Contains the logic that is going to be executed within a transaction.
TransactionalTaskContext - Interface in com.hazelcast.transaction
Provides a context to access transactional data-structures, like the TransactionalMap.
TransactionCommitCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
TransactionCommitCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionCommitCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionCommitMessageTask - Class in com.hazelcast.client.impl.protocol.task.transaction
 
TransactionCommitMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transaction.TransactionCommitMessageTask
 
TransactionContext - Interface in com.hazelcast.transaction
Provides a context to perform transactional operations: beginning/committing transactions, but also retrieving transactional data-structures like the TransactionalMap.
TransactionContextProxy - Class in com.hazelcast.client.impl.proxy.txn
Provides a context to perform transactional operations: beginning/committing transactions, but also retrieving transactional data-structures like the TransactionalMap.
TransactionContextProxy(ClientTransactionManagerServiceImpl, TransactionOptions) - Constructor for class com.hazelcast.client.impl.proxy.txn.TransactionContextProxy
 
TransactionCreateCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
TransactionCreateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionCreateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionCreateMessageTask - Class in com.hazelcast.client.impl.protocol.task.transaction
 
TransactionCreateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transaction.TransactionCreateMessageTask
 
TransactionDataSerializerHook - Class in com.hazelcast.transaction.impl
 
TransactionDataSerializerHook() - Constructor for class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
TransactionException - Exception in com.hazelcast.transaction
A HazelcastException that is thrown when something goes wrong while dealing with transactions and transactional data-structures.
TransactionException() - Constructor for exception com.hazelcast.transaction.TransactionException
 
TransactionException(String) - Constructor for exception com.hazelcast.transaction.TransactionException
 
TransactionException(String, Throwable) - Constructor for exception com.hazelcast.transaction.TransactionException
 
TransactionException(Throwable) - Constructor for exception com.hazelcast.transaction.TransactionException
 
transactionId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionCommitCodec.RequestParameters
The internal Hazelcast transaction id.
transactionId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionRollbackCodec.RequestParameters
The internal Hazelcast transaction id.
transactionId - Variable in class com.hazelcast.client.impl.protocol.codec.XATransactionCommitCodec.RequestParameters
The internal Hazelcast transaction id.
transactionId - Variable in class com.hazelcast.client.impl.protocol.codec.XATransactionPrepareCodec.RequestParameters
The id of the transaction to prepare.
transactionId - Variable in class com.hazelcast.client.impl.protocol.codec.XATransactionRollbackCodec.RequestParameters
The id of the transaction to rollback.
transactionId - Variable in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
 
TransactionImpl - Class in com.hazelcast.transaction.impl
 
TransactionImpl(TransactionManagerServiceImpl, NodeEngine, TransactionOptions, UUID) - Constructor for class com.hazelcast.transaction.impl.TransactionImpl
 
TransactionImpl(TransactionManagerServiceImpl, NodeEngine, TransactionOptions, UUID, boolean) - Constructor for class com.hazelcast.transaction.impl.TransactionImpl
 
TransactionLog - Class in com.hazelcast.transaction.impl
The transaction log contains all TransactionLogRecord for a given transaction.
TransactionLog() - Constructor for class com.hazelcast.transaction.impl.TransactionLog
 
TransactionLog(Collection<TransactionLogRecord>) - Constructor for class com.hazelcast.transaction.impl.TransactionLog
 
TransactionLogRecord - Interface in com.hazelcast.transaction.impl
Represents a change made in a transaction e.g.
TransactionManagerService - Interface in com.hazelcast.transaction
 
TransactionManagerServiceImpl - Class in com.hazelcast.transaction.impl
 
TransactionManagerServiceImpl(NodeEngineImpl) - Constructor for class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
TransactionNotActiveException - Exception in com.hazelcast.transaction
A HazelcastException thrown when an a transactional operation is executed without an active transaction.
TransactionNotActiveException() - Constructor for exception com.hazelcast.transaction.TransactionNotActiveException
 
TransactionNotActiveException(String) - Constructor for exception com.hazelcast.transaction.TransactionNotActiveException
 
TransactionOptions - Class in com.hazelcast.transaction
Contains the configuration for a Hazelcast transaction.
TransactionOptions() - Constructor for class com.hazelcast.transaction.TransactionOptions
Creates a new default configured TransactionsOptions.
TransactionOptions.TransactionType - Enum in com.hazelcast.transaction
The type of transaction.
TransactionPermission - Class in com.hazelcast.security.permission
 
TransactionPermission() - Constructor for class com.hazelcast.security.permission.TransactionPermission
 
TransactionRollbackCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
TransactionRollbackCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionRollbackCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
TransactionRollbackMessageTask - Class in com.hazelcast.client.impl.protocol.task.transaction
 
TransactionRollbackMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transaction.TransactionRollbackMessageTask
 
TransactionTimedOutException - Exception in com.hazelcast.transaction
Thrown when a transaction has timed out.
TransactionTimedOutException() - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
 
TransactionTimedOutException(String) - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
 
TransactionTimedOutException(String, Throwable) - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
 
TransactionTimedOutException(Throwable) - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
 
transactionType - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionCreateCodec.RequestParameters
Identifies the type of the transaction.
TRANSFER_LEADERSHIP_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
transferLeadership(RaftEndpoint) - Method in interface com.hazelcast.cp.internal.raft.impl.RaftNode
Transfers group leadership to the given endpoint, if the local Raft node is the leader with ACTIVE status and the endpoint is a group member.
transferLeadership(RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
transferLeadership(CPGroupId, CPMemberInfo) - Method in class com.hazelcast.cp.internal.RaftService
 
TransferLeadershipOp - Class in com.hazelcast.cp.internal.operation
Triggers the local CP member to transfer Raft group leadership to given CP member for the given CP group
TransferLeadershipOp() - Constructor for class com.hazelcast.cp.internal.operation.TransferLeadershipOp
 
TransferLeadershipOp(CPGroupId, CPMember) - Constructor for class com.hazelcast.cp.internal.operation.TransferLeadershipOp
 
transform(I) - Method in class com.hazelcast.projection.impl.IdentityProjection
 
transform(I) - Method in class com.hazelcast.projection.impl.MultiAttributeProjection
 
transform(I) - Method in class com.hazelcast.projection.impl.SingleAttributeProjection
 
transform(I) - Method in interface com.hazelcast.projection.Projection
Transforms the input object into the output object.
transformToSet(SerializationService, QueryResult, Predicate, IterationType, boolean, boolean) - Static method in class com.hazelcast.map.impl.query.QueryResultUtils
 
translate(Address) - Method in interface com.hazelcast.client.impl.connection.AddressProvider
Translates the given address to another address specific to network or service
translate(Address) - Method in class com.hazelcast.client.impl.spi.impl.DefaultAddressProvider
 
translate(Address) - Method in class com.hazelcast.client.impl.spi.impl.discovery.RemoteAddressProvider
 
transmit(Packet, T) - Method in interface com.hazelcast.internal.nio.EndpointManager
Transmits a packet to a certain connection.
transmit(Packet, Address) - Method in interface com.hazelcast.internal.nio.EndpointManager
Transmits a packet to a certain address.
transmit(Packet, TcpIpConnection) - Method in class com.hazelcast.internal.nio.tcp.ClientViewUnifiedEndpointManager
 
transmit(Packet, Address) - Method in class com.hazelcast.internal.nio.tcp.ClientViewUnifiedEndpointManager
 
transmit(Packet, TcpIpConnection) - Method in class com.hazelcast.internal.nio.tcp.MemberViewUnifiedEndpointManager
 
transmit(Packet, Address) - Method in class com.hazelcast.internal.nio.tcp.MemberViewUnifiedEndpointManager
 
transmit(Packet, TcpIpConnection) - Method in class com.hazelcast.internal.nio.tcp.TcpIpEndpointManager
 
transmit(Packet, Address) - Method in class com.hazelcast.internal.nio.tcp.TcpIpEndpointManager
 
transmit(Packet, TcpIpConnection) - Method in class com.hazelcast.internal.nio.tcp.TextViewUnifiedEndpointManager
 
transmit(Packet, Address) - Method in class com.hazelcast.internal.nio.tcp.TextViewUnifiedEndpointManager
 
TreeMapStreamSerializer<K,V> - Class in com.hazelcast.internal.serialization.impl
The TreeMap serializer
TreeMapStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.TreeMapStreamSerializer
 
TreeSetStreamSerializer<E> - Class in com.hazelcast.internal.serialization.impl
The TreeSet serializer
TreeSetStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.TreeSetStreamSerializer
 
TRIGGER_DESTROY_RAFT_GROUP_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
TRIGGER_EXPLICIT_SUSPICION - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
TRIGGER_LEADER_ELECTION - Static variable in class com.hazelcast.cp.internal.raft.impl.RaftDataSerializerHook
 
TRIGGER_LEADER_ELECTION_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
TRIGGER_LOAD_IF_NEEDED - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
TRIGGER_MEMBER_LIST_PUBLISH - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
triggerAndWaitForReplicaSync(long, TimeUnit) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaStateChecker
 
triggerAntiEntropy() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
triggerDestroyRaftGroup(CPGroupId) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
TriggerDestroyRaftGroupOp - Class in com.hazelcast.cp.internal.raftop.metadata
Initiates the destroy process for the given Raft group.
TriggerDestroyRaftGroupOp() - Constructor for class com.hazelcast.cp.internal.raftop.metadata.TriggerDestroyRaftGroupOp
 
TriggerDestroyRaftGroupOp(CPGroupId) - Constructor for class com.hazelcast.cp.internal.raftop.metadata.TriggerDestroyRaftGroupOp
 
TriggerExplicitSuspicionOp - Class in com.hazelcast.internal.cluster.impl.operations
An operation which is sent to trigger ExplicitSuspicionOp on target member.
TriggerExplicitSuspicionOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.TriggerExplicitSuspicionOp
 
TriggerExplicitSuspicionOp(int, MembersViewMetadata) - Constructor for class com.hazelcast.internal.cluster.impl.operations.TriggerExplicitSuspicionOp
 
triggerForceStart() - Method in interface com.hazelcast.internal.hotrestart.InternalHotRestartService
Forces node to start by skipping hot-restart completely and removing all hot-restart data even if node is still on validation phase or loading hot-restart data.
triggerForceStart() - Method in class com.hazelcast.internal.hotrestart.NoopInternalHotRestartService
 
TriggerLeaderElection - Class in com.hazelcast.cp.internal.raft.impl.dto
Struct for the leadership transfer logic.
TriggerLeaderElection() - Constructor for class com.hazelcast.cp.internal.raft.impl.dto.TriggerLeaderElection
 
TriggerLeaderElection(RaftEndpoint, int, int, long) - Constructor for class com.hazelcast.cp.internal.raft.impl.dto.TriggerLeaderElection
 
TriggerLeaderElectionHandlerTask - Class in com.hazelcast.cp.internal.raft.impl.handler
TriggerLeaderElectionHandlerTask(RaftNodeImpl, TriggerLeaderElection) - Constructor for class com.hazelcast.cp.internal.raft.impl.handler.TriggerLeaderElectionHandlerTask
 
TriggerLeaderElectionOp - Class in com.hazelcast.cp.internal.operation.integration
Carries a TriggerLeaderElection from a Raft leader to a follower
TriggerLeaderElectionOp() - Constructor for class com.hazelcast.cp.internal.operation.integration.TriggerLeaderElectionOp
 
TriggerLeaderElectionOp(CPGroupId, TriggerLeaderElection) - Constructor for class com.hazelcast.cp.internal.operation.integration.TriggerLeaderElectionOp
 
TriggerLoadIfNeededOperation - Class in com.hazelcast.map.impl.operation
Triggers key loading on member with MapKeyLoader.Role.SENDER or MapKeyLoader.Role.SENDER_BACKUP key loader role if keys have not yet been loaded.
TriggerLoadIfNeededOperation() - Constructor for class com.hazelcast.map.impl.operation.TriggerLoadIfNeededOperation
 
TriggerLoadIfNeededOperation(String) - Constructor for class com.hazelcast.map.impl.operation.TriggerLoadIfNeededOperation
 
triggerLoadingWithDelay() - Method in class com.hazelcast.map.impl.MapKeyLoader
Triggers key loading on SENDER if it hadn't started.
TriggerMemberListPublishOp - Class in com.hazelcast.internal.cluster.impl.operations
Requests member list publish from master node
TriggerMemberListPublishOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.TriggerMemberListPublishOp
 
triggerPartialStart() - Method in interface com.hazelcast.internal.hotrestart.InternalHotRestartService
Triggers partial start if the cluster cannot be started with full recovery and HotRestartPersistenceConfig.clusterDataRecoveryPolicy is set accordingly.
triggerPartialStart() - Method in class com.hazelcast.internal.hotrestart.NoopInternalHotRestartService
 
TriggerPartialStartRequest - Class in com.hazelcast.internal.management.request
Request coming from Management Center to trigger partial start during Hot Restart process
TriggerPartialStartRequest() - Constructor for class com.hazelcast.internal.management.request.TriggerPartialStartRequest
 
triggerPartitionReplicaSync(int, Collection<ServiceNamespace>, int) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
This method is called on a backup node (replica).
trim(String) - Static method in class com.hazelcast.internal.util.StringUtil
Trim whitespaces.
trimToSize() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray
Compact the array by reducing its capacity, if allowed by the current size and load factor.
trimToSize() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
TriTuple<X,Y,Z> - Class in com.hazelcast.internal.util
An immutable container of 3 statically typed fields
TRUE - Static variable in class com.hazelcast.internal.json.Json
Represents the JSON literal true.
TRUE - Static variable in class com.hazelcast.internal.json.JsonValue
Deprecated.
Use Json.TRUE instead
TRUE_EVENT_FILTER - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
TRUE_FILTER - Static variable in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationUtils
 
TRUE_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
 
TrueEventFilter - Class in com.hazelcast.spi.impl.eventservice.impl
An event filter which does not filter any event and always evaluates true results.
TrueEventFilter() - Constructor for class com.hazelcast.spi.impl.eventservice.impl.TrueEventFilter
 
TruePredicate<K,V> - Class in com.hazelcast.query.impl.predicates
A Predicate which always returns true.
TruePredicate() - Constructor for class com.hazelcast.query.impl.predicates.TruePredicate
 
truePredicate() - Static method in class com.hazelcast.query.impl.predicates.TruePredicate
 
TRY_LOCK_OP - Static variable in class com.hazelcast.cp.internal.datastructures.lock.LockDataSerializerHook
 
TRY_PUT - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
TRY_REMOVE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
TRY_SET_COUNT_OP - Static variable in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchDataSerializerHook
 
tryAck(long, RaftEndpoint) - Method in class com.hazelcast.cp.internal.raft.impl.state.QueryState
Returns true if the given follower is accepted as an acker for the current query round.
tryAcquire() - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionAwareSemaphoreProxy
 
tryAcquire(int) - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionAwareSemaphoreProxy
 
tryAcquire(long, TimeUnit) - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionAwareSemaphoreProxy
 
tryAcquire(int, long, TimeUnit) - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionAwareSemaphoreProxy
 
tryAcquire() - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionlessSemaphoreProxy
 
tryAcquire(int) - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionlessSemaphoreProxy
 
tryAcquire(long, TimeUnit) - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionlessSemaphoreProxy
 
tryAcquire(int, long, TimeUnit) - Method in class com.hazelcast.client.cp.internal.datastructures.semaphore.SessionlessSemaphoreProxy
 
tryAcquire() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionAwareSemaphoreProxy
 
tryAcquire(int) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionAwareSemaphoreProxy
 
tryAcquire(long, TimeUnit) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionAwareSemaphoreProxy
 
tryAcquire(int, long, TimeUnit) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionAwareSemaphoreProxy
 
tryAcquire() - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionlessSemaphoreProxy
 
tryAcquire(int) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionlessSemaphoreProxy
 
tryAcquire(long, TimeUnit) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionlessSemaphoreProxy
 
tryAcquire(int, long, TimeUnit) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.proxy.SessionlessSemaphoreProxy
 
tryAcquire() - Method in interface com.hazelcast.cp.ISemaphore
Acquires a permit if one is available, and returns true immediately.
tryAcquire(int) - Method in interface com.hazelcast.cp.ISemaphore
Acquires the given number of permits if they are available, and returns true immediately.
tryAcquire(long, TimeUnit) - Method in interface com.hazelcast.cp.ISemaphore
Acquires a permit and returns true, if one becomes available during the given waiting time and the current thread has not been interrupted.
tryAcquire(int, long, TimeUnit) - Method in interface com.hazelcast.cp.ISemaphore
Acquires the given number of permits and returns true, if they become available during the given waiting time.
tryAcquire() - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationQueue
 
tryAcquireReplicaSyncPermits(int) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
Tries to acquire requested permits.
tryAdvanceCommitIndex() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
tryCloseConnections(HazelcastInstance) - Method in class com.hazelcast.core.OutOfMemoryHandler
Tries to close the server socket and connections to other HazelcastInstances.
tryCloseConnections(HazelcastInstance) - Static method in class com.hazelcast.instance.impl.OutOfMemoryHandlerHelper
 
tryCount - Variable in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
 
tryCreateQueryCache(String, String, ConstructorFunction<String, InternalQueryCache<K, V>>) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheEndToEndProvider
Idempotent query cache create mechanism.
tryEvict(C, EvictionListener<Data, CacheRecord>) - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap
 
tryEvict(C, EvictionListener<A, E>) - Method in interface com.hazelcast.internal.eviction.EvictableStore
The evict method is called by the EvictionStrategy to eventually evict, by the policy, selected candidate from the internal data structures.
tryEvict(C, EvictionListener<K, V>) - Method in class com.hazelcast.internal.nearcache.impl.store.HeapNearCacheRecordMap
 
tryEvict(C, EvictionListener<Data, QueryCacheRecord>) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRecordHashMap
 
tryLoadClass(String) - Static method in class com.hazelcast.internal.nio.ClassLoaderUtil
Tries to load the given class.
tryLock() - Method in class com.hazelcast.client.cp.internal.datastructures.lock.FencedLockProxy
 
tryLock(long, TimeUnit) - Method in class com.hazelcast.client.cp.internal.datastructures.lock.FencedLockProxy
 
tryLock(K) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
tryLock(K, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
tryLock(K, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
tryLock(K) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
tryLock(K, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
tryLock(K, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
tryLock() - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
tryLock(long, TimeUnit) - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
tryLock() - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock if it is available or already held by the current thread at the time of invocation & the acquire limit is not exceeded, and immediately returns with the value true.
tryLock(long, TimeUnit) - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock if it is free within the given waiting time, or already held by the current thread.
tryLock(NodeEngine, Data) - Method in class com.hazelcast.internal.locksupport.LockProxySupport
 
tryLock(NodeEngine, Data, long, TimeUnit) - Method in class com.hazelcast.internal.locksupport.LockProxySupport
 
tryLock(NodeEngine, Data, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.internal.locksupport.LockProxySupport
 
tryLock(K) - Method in interface com.hazelcast.map.IMap
Tries to acquire the lock for the specified key.
tryLock(K, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Tries to acquire the lock for the specified key.
tryLock(K, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Tries to acquire the lock for the specified key for the specified lease time.
tryLock(K) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
tryLock(K, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
tryLock(K, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
tryLock(K) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
tryLock(K, long, TimeUnit) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
tryLock(K, long, TimeUnit, long, TimeUnit) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
tryLock(K) - Method in interface com.hazelcast.multimap.MultiMap
Tries to acquire the lock for the specified key.
tryLock(K, long, TimeUnit) - Method in interface com.hazelcast.multimap.MultiMap
Tries to acquire the lock for the specified key.
tryLock(K, long, TimeUnit, long, TimeUnit) - Method in interface com.hazelcast.multimap.MultiMap
Tries to acquire the lock for the specified key for the specified lease time.
tryLockAndGetFence() - Method in class com.hazelcast.client.cp.internal.datastructures.lock.FencedLockProxy
 
tryLockAndGetFence(long, TimeUnit) - Method in class com.hazelcast.client.cp.internal.datastructures.lock.FencedLockProxy
 
tryLockAndGetFence() - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
tryLockAndGetFence(long, TimeUnit) - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
tryLockAndGetFence() - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock only if it is free or already held by the current thread at the time of invocation & the acquire limit is not exceeded, and returns the fencing token assigned to the current thread for this lock acquire.
tryLockAndGetFence(long, TimeUnit) - Method in interface com.hazelcast.cp.lock.FencedLock
Acquires the lock if it is free within the given waiting time, or already held by the current thread at the time of invocation & the acquire limit is not exceeded, and returns the fencing token assigned to the current thread for this lock acquire.
TryLockMessageTask - Class in com.hazelcast.cp.internal.datastructures.lock.client
Client message task for TryLockOp
TryLockMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.lock.client.TryLockMessageTask
 
TryLockOp - Class in com.hazelcast.cp.internal.datastructures.lock.operation
Operation for FencedLock.lock()
TryLockOp() - Constructor for class com.hazelcast.cp.internal.datastructures.lock.operation.TryLockOp
 
TryLockOp(String, long, long, UUID, long) - Constructor for class com.hazelcast.cp.internal.datastructures.lock.operation.TryLockOp
 
tryMarkAPMember() - Method in interface com.hazelcast.cp.internal.persistence.CPMetadataStore
Marks this member as AP member on the storage layer, if it is not a CP member already.
tryMarkAPMember() - Method in class com.hazelcast.cp.internal.persistence.NopCPMetadataStore
 
tryPauseMillis - Variable in class com.hazelcast.spi.impl.operationservice.InvocationBuilder
 
tryPublishReserved(K, V, long, boolean) - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
tryPublishReserved(K, V, long, boolean) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
tryPublishReserved(K, V, long, boolean) - Method in interface com.hazelcast.internal.nearcache.NearCache
Tries to update reserved key with supplied value.
tryPublishReserved(K, V, long, boolean) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
Tries to update reserved key with supplied value.
tryPut(K, V, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
tryPut(K, V, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Tries to put the given key and value into this map within a specified timeout value.
tryPut(K, V, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
tryPutInternal(long, TimeUnit, Object, Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
tryPutInternal(long, TimeUnit, Object, Object) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
tryPutInternal(Object, Data, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
TryPutOperation - Class in com.hazelcast.map.impl.operation
 
TryPutOperation() - Constructor for class com.hazelcast.map.impl.operation.TryPutOperation
 
TryPutOperation(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.operation.TryPutOperation
 
tryRecover() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
tryRecover() - Method in interface com.hazelcast.map.QueryCache
This method can be used to recover from a possible event loss situation.
tryRemove(K, long, TimeUnit) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
tryRemove(K, long, TimeUnit) - Method in interface com.hazelcast.map.IMap
Tries to remove the entry with the given key from this map within the specified timeout value.
tryRemove(K, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
tryRemoveInternal(long, TimeUnit, Object) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
tryRemoveInternal(long, TimeUnit, Object) - Method in class com.hazelcast.client.impl.proxy.NearCachedClientMapProxy
 
tryRemoveInternal(Object, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
 
TryRemoveOperation - Class in com.hazelcast.map.impl.operation
 
TryRemoveOperation() - Constructor for class com.hazelcast.map.impl.operation.TryRemoveOperation
 
TryRemoveOperation(String, Data, long) - Constructor for class com.hazelcast.map.impl.operation.TryRemoveOperation
 
tryReserveForUpdate(K, Data) - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
tryReserveForUpdate(K, Data) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
tryReserveForUpdate(K, Data) - Method in interface com.hazelcast.internal.nearcache.NearCache
Tries to reserve supplied key for update.
tryReserveForUpdate(K, Data) - Method in interface com.hazelcast.internal.nearcache.NearCacheRecordStore
Tries to reserve supplied key for update.
tryRunQueries() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
trySendExpiryOp(RS, InvalidationQueue, int, int, boolean) - Method in class com.hazelcast.internal.eviction.ToBackupSender
 
trySetCount(int) - Method in class com.hazelcast.client.cp.internal.datastructures.countdownlatch.CountDownLatchProxy
 
trySetCount(int) - Method in interface com.hazelcast.cp.ICountDownLatch
Sets the count to the given value if the current count is zero.
trySetCount(CPGroupId, String, int) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatchService
 
trySetCount(int) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.proxy.CountDownLatchProxy
 
TrySetCountMessageTask - Class in com.hazelcast.cp.internal.datastructures.countdownlatch.client
Client message task for TrySetCountOp
TrySetCountMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.client.TrySetCountMessageTask
 
TrySetCountOp - Class in com.hazelcast.cp.internal.datastructures.countdownlatch.operation
TrySetCountOp() - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.TrySetCountOp
 
TrySetCountOp(String, int) - Constructor for class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.TrySetCountOp
 
trySetMigratingFlag(int) - Method in class com.hazelcast.internal.partition.impl.PartitionStateManager
 
tryShutdown(HazelcastInstance) - Method in class com.hazelcast.core.OutOfMemoryHandler
Tries to shutdown HazelcastInstance forcefully; including closing sockets and connections, stopping threads, etc.
tryShutdown(HazelcastInstance) - Static method in class com.hazelcast.instance.impl.OutOfMemoryHandlerHelper
 
tryToSendBackupExpiryOp(ICacheRecordStore, boolean) - Method in class com.hazelcast.cache.impl.eviction.CacheClearExpiredRecordsTask
 
tryToSendBackupExpiryOp(S, boolean) - Method in class com.hazelcast.internal.eviction.ClearExpiredRecordsTask
 
tryToSendBackupExpiryOp(RecordStore, boolean) - Method in class com.hazelcast.map.impl.eviction.MapClearExpiredRecordsTask
 
ttl - Variable in class com.hazelcast.client.impl.protocol.codec.MapLockCodec.RequestParameters
The duration in milliseconds after which this entry shall be deleted.
ttl - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutCodec.RequestParameters
The duration in milliseconds after which this entry shall be deleted.
ttl - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentCodec.RequestParameters
The duration in milliseconds after which this entry shall be deleted.
ttl - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentWithMaxIdleCodec.RequestParameters
The duration in milliseconds after which this entry shall be deleted.
ttl - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutTransientCodec.RequestParameters
The duration in milliseconds after which this entry shall be deleted.
ttl - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutTransientWithMaxIdleCodec.RequestParameters
The duration in milliseconds after which this entry shall be deleted.
ttl - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutWithMaxIdleCodec.RequestParameters
The duration in milliseconds after which this entry shall be deleted.
ttl - Variable in class com.hazelcast.client.impl.protocol.codec.MapSetCodec.RequestParameters
The duration in milliseconds after which this entry shall be deleted.
ttl - Variable in class com.hazelcast.client.impl.protocol.codec.MapSetTtlCodec.RequestParameters
The duration in milliseconds after which this entry shall be deleted.
ttl - Variable in class com.hazelcast.client.impl.protocol.codec.MapSetWithMaxIdleCodec.RequestParameters
The duration in milliseconds after which this entry shall be deleted.
ttl - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapLockCodec.RequestParameters
The duration in milliseconds after which this entry shall be deleted.
ttl - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutCodec.RequestParameters
ttl in milliseconds to be associated with the specified key-value pair
ttl - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutCodec.RequestParameters
The duration in milliseconds after which this entry shall be deleted.
ttl - Variable in class com.hazelcast.map.impl.record.AbstractRecord
 
ttl - Variable in class com.hazelcast.map.impl.record.RecordInfo
 
ttl - Variable in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
 
ttlMillis - Variable in class com.hazelcast.client.impl.protocol.codec.CPSessionCreateSessionCodec.ResponseParameters
TODO DOC
tx - Variable in class com.hazelcast.spi.impl.TransactionalDistributedObject
 
TX_COLLECTION_ITEM - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
TX_QUEUE_ITEM - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
TX_ROLLBACK - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
TxCollectionItem - Class in com.hazelcast.collection.impl.collection
 
TxCollectionItem() - Constructor for class com.hazelcast.collection.impl.collection.TxCollectionItem
 
TxCollectionItem(CollectionItem) - Constructor for class com.hazelcast.collection.impl.collection.TxCollectionItem
 
TxCollectionItem(long, Data, UUID, boolean) - Constructor for class com.hazelcast.collection.impl.collection.TxCollectionItem
 
txMap - Variable in class com.hazelcast.collection.impl.collection.CollectionContainer
 
txMapSize() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
 
TXN_COMMIT - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
TXN_COMMIT - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
TXN_COMMIT - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
TXN_COMMIT_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
 
TXN_COMMIT_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
TXN_COMMIT_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
TXN_DELETE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
TXN_DELETE_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
TXN_GENERATE_RECORD_ID - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
TXN_LOCK_AND_GET - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
TXN_LOCK_AND_GET - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
TXN_OFFER - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
TXN_OFFER_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
TXN_PEEK - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
TXN_POLL - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
TXN_POLL_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
TXN_PREPARE - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
TXN_PREPARE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
TXN_PREPARE - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
TXN_PREPARE_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
TXN_PREPARE_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
TXN_PREPARE_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
TXN_PUT - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
TXN_PUT_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
TXN_REMOVE - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
TXN_REMOVE_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
TXN_REMOVE_ALL_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
TXN_REMOVE_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
TXN_RESERVE_OFFER - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
TXN_RESERVE_OFFER_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
TXN_RESERVE_POLL - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
TXN_RESERVE_POLL_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
TXN_ROLLBACK - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
TXN_ROLLBACK - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
TXN_ROLLBACK - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
TXN_ROLLBACK_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
TXN_ROLLBACK_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
TXN_ROLLBACK_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
TXN_SET - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
TXN_SET_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
TXN_UNLOCK - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
TXN_UNLOCK_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
txnCheckReserve(long) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Checks if there is a reserved item (within a transaction) with the given itemId.
TxnCommitBackupOperation - Class in com.hazelcast.collection.impl.txnqueue.operations
a wrapper for running all commit backup operations at once
TxnCommitBackupOperation() - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitBackupOperation
 
TxnCommitBackupOperation(String, List<Operation>) - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitBackupOperation
 
TxnCommitBackupOperation - Class in com.hazelcast.multimap.impl.txn
 
TxnCommitBackupOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnCommitBackupOperation
 
TxnCommitBackupOperation(String, Data, List<Operation>, UUID, long) - Constructor for class com.hazelcast.multimap.impl.txn.TxnCommitBackupOperation
 
txnCommitOffer(long, Data, boolean) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Sets the data of a reserved item and commits the change so it can be visible outside a transaction.
TxnCommitOperation - Class in com.hazelcast.collection.impl.txnqueue.operations
a wrapper for running all commit operations at once
TxnCommitOperation() - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitOperation
 
TxnCommitOperation(int, String, List<Operation>) - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitOperation
 
TxnCommitOperation - Class in com.hazelcast.multimap.impl.txn
 
TxnCommitOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnCommitOperation
 
TxnCommitOperation(int, String, Data, long, List<Operation>) - Constructor for class com.hazelcast.multimap.impl.txn.TxnCommitOperation
 
txnCommitPoll(long) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
 
txnCommitPollBackup(long) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Commits the effects of the QueueContainer.txnPollReserve(long, UUID)}.
TxnDeleteBackupOperation - Class in com.hazelcast.map.impl.tx
 
TxnDeleteBackupOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnDeleteBackupOperation
 
TxnDeleteBackupOperation(String, Data, UUID) - Constructor for class com.hazelcast.map.impl.tx.TxnDeleteBackupOperation
 
TxnDeleteOperation - Class in com.hazelcast.map.impl.tx
Transactional delete operation
TxnDeleteOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnDeleteOperation
 
TxnDeleteOperation(String, Data, long) - Constructor for class com.hazelcast.map.impl.tx.TxnDeleteOperation
 
txnEnsureBackupReserve(long, UUID, boolean) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
 
TxnGenerateRecordIdOperation - Class in com.hazelcast.multimap.impl.txn
 
TxnGenerateRecordIdOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnGenerateRecordIdOperation
 
TxnGenerateRecordIdOperation(String, Data) - Constructor for class com.hazelcast.multimap.impl.txn.TxnGenerateRecordIdOperation
 
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListAddCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListRemoveCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalListSizeCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsKeyCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsValueCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapDeleteCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapGetForUpdateCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapIsEmptyCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapKeySetWithPredicateCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutIfAbsentCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveIfSameCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceIfSameCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSetCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSizeCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapValuesWithPredicateCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapGetCodec.RequestParameters
ID of the transaction
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapPutCodec.RequestParameters
ID of the transaction
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveCodec.RequestParameters
ID of the transaction
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveEntryCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapSizeCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapValueCountCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueOfferCodec.RequestParameters
ID of the transaction
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePeekCodec.RequestParameters
ID of the transaction
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueuePollCodec.RequestParameters
ID of the transaction
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueSizeCodec.RequestParameters
ID of the transaction
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalQueueTakeCodec.RequestParameters
ID of the transaction
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetAddCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetRemoveCodec.RequestParameters
ID of the this transaction operation
txnId - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalSetSizeCodec.RequestParameters
ID of the this transaction operation
txnLock(Data, UUID, long, long, long, boolean) - Method in interface com.hazelcast.internal.locksupport.LockStore
Lock a specific key for use inside a transaction.
txnLock(Data, UUID, long, long, long, boolean) - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
txnLock(Data, UUID, long, long, long, boolean) - Method in class com.hazelcast.internal.locksupport.LockStoreProxy
 
txnLock(Data, UUID, long, long, long, boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
txnLock(Data, UUID, long, long, long, boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
txnLock(Data, UUID, long, long, long, boolean) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
TxnLockAndGetOperation - Class in com.hazelcast.map.impl.tx
Transactional lock and get operation.
TxnLockAndGetOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
 
TxnLockAndGetOperation(String, Data, long, long, UUID, boolean, boolean) - Constructor for class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
 
TxnLockAndGetOperation - Class in com.hazelcast.multimap.impl.txn
 
TxnLockAndGetOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
 
TxnLockAndGetOperation(String, Data, long, long, long, boolean) - Constructor for class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
 
TxnOfferBackupOperation - Class in com.hazelcast.collection.impl.txnqueue.operations
Provides backup operation during transactional offer operation.
TxnOfferBackupOperation() - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferBackupOperation
 
TxnOfferBackupOperation(String, long, Data) - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferBackupOperation
 
txnOfferBackupReserve(long, UUID) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Reserves an ID for a future queue item and associates it with the given transactionId.
TxnOfferOperation - Class in com.hazelcast.collection.impl.txnqueue.operations
Transaction commit operation for a queue offer, executed on the primary replica.
TxnOfferOperation() - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
 
TxnOfferOperation(String, long, Data) - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
 
txnOfferReserve(UUID) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Reserves an ID for a future queue item and associates it with the given transactionId.
txnPeek(long, UUID) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Retrieves, but does not remove, the head of the queue.
TxnPeekOperation - Class in com.hazelcast.collection.impl.txnqueue.operations
Peek operation for the transactional queue.
TxnPeekOperation() - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnPeekOperation
 
TxnPeekOperation(String, long, long, UUID) - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnPeekOperation
 
TxnPollBackupOperation - Class in com.hazelcast.collection.impl.txnqueue.operations
Provides backup operation during transactional poll operation.
TxnPollBackupOperation() - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnPollBackupOperation
 
TxnPollBackupOperation(String, long) - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnPollBackupOperation
 
txnPollBackupReserve(long, UUID) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Makes a reservation for a poll operation.
TxnPollOperation - Class in com.hazelcast.collection.impl.txnqueue.operations
Poll operation for the transactional queue.
TxnPollOperation() - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnPollOperation
 
TxnPollOperation(String, long) - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnPollOperation
 
txnPollReserve(long, UUID) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Tries to obtain an item by removing the head of the queue or removing an item previously reserved by invoking QueueContainer.txnOfferReserve(UUID) with reservedOfferId.
TxnPrepareBackupOperation - Class in com.hazelcast.collection.impl.txnqueue.operations
Provides backup operation during transactional prepare operation.
TxnPrepareBackupOperation() - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareBackupOperation
 
TxnPrepareBackupOperation(String, long[], UUID) - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareBackupOperation
 
TxnPrepareBackupOperation - Class in com.hazelcast.map.impl.tx
An operation to prepare transaction by locking the key on key backup owner.
TxnPrepareBackupOperation(String, Data, UUID, long, UUID) - Constructor for class com.hazelcast.map.impl.tx.TxnPrepareBackupOperation
 
TxnPrepareBackupOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnPrepareBackupOperation
 
TxnPrepareBackupOperation - Class in com.hazelcast.multimap.impl.txn
 
TxnPrepareBackupOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnPrepareBackupOperation
 
TxnPrepareBackupOperation(String, Data, long, UUID) - Constructor for class com.hazelcast.multimap.impl.txn.TxnPrepareBackupOperation
 
TxnPrepareOperation - Class in com.hazelcast.collection.impl.txnqueue.operations
Prepare operation for the transactional queue.
TxnPrepareOperation() - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareOperation
 
TxnPrepareOperation(int, String, long[], UUID) - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareOperation
 
TxnPrepareOperation - Class in com.hazelcast.map.impl.tx
An operation to prepare transaction by locking the key on the key owner.
TxnPrepareOperation(int, String, Data, UUID, UUID) - Constructor for class com.hazelcast.map.impl.tx.TxnPrepareOperation
 
TxnPrepareOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnPrepareOperation
 
TxnPrepareOperation - Class in com.hazelcast.multimap.impl.txn
 
TxnPrepareOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
 
TxnPrepareOperation(int, String, Data, long) - Constructor for class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
 
TxnPutBackupOperation - Class in com.hazelcast.multimap.impl.txn
 
TxnPutBackupOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnPutBackupOperation
 
TxnPutBackupOperation(String, Data, long, Data) - Constructor for class com.hazelcast.multimap.impl.txn.TxnPutBackupOperation
 
TxnPutOperation - Class in com.hazelcast.multimap.impl.txn
 
TxnPutOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnPutOperation
 
TxnPutOperation(String, Data, Data, long) - Constructor for class com.hazelcast.multimap.impl.txn.TxnPutOperation
 
TxnRemoveAllBackupOperation - Class in com.hazelcast.multimap.impl.txn
 
TxnRemoveAllBackupOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnRemoveAllBackupOperation
 
TxnRemoveAllBackupOperation(String, Data, Collection<Long>) - Constructor for class com.hazelcast.multimap.impl.txn.TxnRemoveAllBackupOperation
 
TxnRemoveAllOperation - Class in com.hazelcast.multimap.impl.txn
 
TxnRemoveAllOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
 
TxnRemoveAllOperation(String, Data, Collection<MultiMapRecord>) - Constructor for class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
 
TxnRemoveBackupOperation - Class in com.hazelcast.multimap.impl.txn
 
TxnRemoveBackupOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnRemoveBackupOperation
 
TxnRemoveBackupOperation(String, Data, long, Data) - Constructor for class com.hazelcast.multimap.impl.txn.TxnRemoveBackupOperation
 
TxnRemoveOperation - Class in com.hazelcast.multimap.impl.txn
 
TxnRemoveOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
 
TxnRemoveOperation(String, Data, long, Data) - Constructor for class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
 
TxnReservedCapacityCounter - Interface in com.hazelcast.map.impl.mapstore.writebehind
This interface contains methods to increment/decrement reserved capacity of a write behind queue.
TxnReservedCapacityCounterImpl - Class in com.hazelcast.map.impl.mapstore.writebehind
This class represents capacity counters for write behind queueing.
TxnReservedCapacityCounterImpl(NodeWideUsedCapacityCounter) - Constructor for class com.hazelcast.map.impl.mapstore.writebehind.TxnReservedCapacityCounterImpl
 
TxnReserveOfferBackupOperation - Class in com.hazelcast.collection.impl.txnqueue.operations
Transaction prepare operation for a queue offer, executed on the backup replica.
TxnReserveOfferBackupOperation() - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferBackupOperation
 
TxnReserveOfferBackupOperation(String, long, UUID) - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferBackupOperation
 
TxnReserveOfferOperation - Class in com.hazelcast.collection.impl.txnqueue.operations
Transaction prepare operation for a queue offer, executed on the primary replica.
TxnReserveOfferOperation() - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferOperation
 
TxnReserveOfferOperation(String, long, int, UUID) - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferOperation
 
TxnReservePollBackupOperation - Class in com.hazelcast.collection.impl.txnqueue.operations
Transaction prepare operation for a queue poll, executed on the backup replica.
TxnReservePollBackupOperation() - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollBackupOperation
 
TxnReservePollBackupOperation(String, long, UUID) - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollBackupOperation
 
TxnReservePollOperation - Class in com.hazelcast.collection.impl.txnqueue.operations
Transaction prepare operation for a queue poll, executed on the primary replica.
TxnReservePollOperation() - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollOperation
 
TxnReservePollOperation(String, long, long, UUID) - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollOperation
 
TxnRollbackBackupOperation - Class in com.hazelcast.collection.impl.txnqueue.operations
Provides backup operation during transactional rollback operation.
TxnRollbackBackupOperation() - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackBackupOperation
 
TxnRollbackBackupOperation(String, long[]) - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackBackupOperation
 
TxnRollbackBackupOperation - Class in com.hazelcast.map.impl.tx
An operation to rollback transaction by unlocking the key on key backup owner.
TxnRollbackBackupOperation(String, Data, UUID, long, UUID) - Constructor for class com.hazelcast.map.impl.tx.TxnRollbackBackupOperation
 
TxnRollbackBackupOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnRollbackBackupOperation
 
TxnRollbackBackupOperation - Class in com.hazelcast.multimap.impl.txn
 
TxnRollbackBackupOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnRollbackBackupOperation
 
TxnRollbackBackupOperation(String, Data, UUID, long) - Constructor for class com.hazelcast.multimap.impl.txn.TxnRollbackBackupOperation
 
txnRollbackOffer(long) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Removes a reserved item with the given itemId.
txnRollbackOfferBackup(long) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Removes a reserved item with the given itemId.
TxnRollbackOperation - Class in com.hazelcast.collection.impl.txnqueue.operations
Rollback operation for the transactional queue.
TxnRollbackOperation() - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackOperation
 
TxnRollbackOperation(int, String, long[]) - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackOperation
 
TxnRollbackOperation - Class in com.hazelcast.map.impl.tx
An operation to rollback transaction by unlocking the key on key owner.
TxnRollbackOperation(int, String, Data, UUID, UUID) - Constructor for class com.hazelcast.map.impl.tx.TxnRollbackOperation
 
TxnRollbackOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnRollbackOperation
 
TxnRollbackOperation - Class in com.hazelcast.multimap.impl.txn
 
TxnRollbackOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnRollbackOperation
 
TxnRollbackOperation(int, String, Data, long) - Constructor for class com.hazelcast.multimap.impl.txn.TxnRollbackOperation
 
txnRollbackPoll(long, boolean) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
Rolls back the effects of the QueueContainer.txnPollReserve(long, UUID).
TxnSetBackupOperation - Class in com.hazelcast.map.impl.tx
 
TxnSetBackupOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnSetBackupOperation
 
TxnSetBackupOperation(String, Data, Data, RecordInfo, UUID) - Constructor for class com.hazelcast.map.impl.tx.TxnSetBackupOperation
 
TxnSetOperation - Class in com.hazelcast.map.impl.tx
An operation to unlock and set (key,value) on the partition .
TxnSetOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnSetOperation
 
TxnSetOperation(String, Data, Data, long, long) - Constructor for class com.hazelcast.map.impl.tx.TxnSetOperation
 
TxnUnlockBackupOperation - Class in com.hazelcast.map.impl.tx
An operation to unlock key on the backup owner.
TxnUnlockBackupOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnUnlockBackupOperation
 
TxnUnlockBackupOperation(String, Data, UUID, long) - Constructor for class com.hazelcast.map.impl.tx.TxnUnlockBackupOperation
 
TxnUnlockOperation - Class in com.hazelcast.map.impl.tx
An operation to unlock key on the partition owner.
TxnUnlockOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnUnlockOperation
 
TxnUnlockOperation(String, Data, long) - Constructor for class com.hazelcast.map.impl.tx.TxnUnlockOperation
 
TxQueueItem - Class in com.hazelcast.collection.impl.txnqueue
Transactional Queue Item.
TxQueueItem() - Constructor for class com.hazelcast.collection.impl.txnqueue.TxQueueItem
 
TxQueueItem(QueueItem) - Constructor for class com.hazelcast.collection.impl.txnqueue.TxQueueItem
 
TxQueueItem(QueueContainer, long, Data) - Constructor for class com.hazelcast.collection.impl.txnqueue.TxQueueItem
 
type - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToAddressCodec.RequestParameters
type of schedule logic, values 0 for SINGLE_RUN, 1 for AT_FIXED_RATE
type - Variable in class com.hazelcast.client.impl.protocol.codec.ScheduledExecutorSubmitToPartitionCodec.RequestParameters
type of schedule logic, values 0 for SINGLE_RUN, 1 for AT_FIXED_RATE
type - Variable in class com.hazelcast.internal.ascii.AbstractTextCommand
 
type - Variable in class com.hazelcast.internal.ascii.TypeAwareCommandParser
 
type - Variable in class com.hazelcast.internal.management.dto.ClientBwListEntryDTO
 
TYPE_CACHE_PARTITION_LOST_LISTENER_CONFIG - Static variable in class com.hazelcast.client.impl.protocol.task.dynamicconfig.ListenerConfigHolder
 
TYPE_ENTRY_LISTENER_CONFIG - Static variable in class com.hazelcast.client.impl.protocol.task.dynamicconfig.ListenerConfigHolder
 
TYPE_FIELD_OFFSET - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
TYPE_ITEM_LISTENER_CONFIG - Static variable in class com.hazelcast.client.impl.protocol.task.dynamicconfig.ListenerConfigHolder
 
TYPE_LENGTH - Static variable in class com.hazelcast.client.impl.ClientTypes
Length of type information in bytes
TYPE_LISTENER_CONFIG - Static variable in class com.hazelcast.client.impl.protocol.task.dynamicconfig.ListenerConfigHolder
 
TYPE_MAP_PARTITION_LOST_LISTENER_CONFIG - Static variable in class com.hazelcast.client.impl.protocol.task.dynamicconfig.ListenerConfigHolder
 
TYPE_OFFSET - Static variable in class com.hazelcast.internal.serialization.impl.HeapData
 
TYPE_SPLIT_BRAIN_PROTECTION_LISTENER_CONFIG - Static variable in class com.hazelcast.client.impl.protocol.task.dynamicconfig.ListenerConfigHolder
 
TypeAwareCommandParser - Class in com.hazelcast.internal.ascii
 
TypeAwareCommandParser(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.internal.ascii.TypeAwareCommandParser
 
typeConverter() - Method in interface com.hazelcast.config.properties.PropertyDefinition
The TypeConverter to be used to convert the string value read from XML to the expected type automatically.
typeConverter() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
 
TypeConverter - Interface in com.hazelcast.core
Implementations of this interface define a certain type conversation.
TypeConverters - Class in com.hazelcast.query.impl
 
TypeConverters.BaseTypeConverter - Class in com.hazelcast.query.impl
 
TypedByteArrayDeserializer<T> - Interface in com.hazelcast.nio.serialization
This interface allows deserialization of a binary data with a provided class type.
TypedDataSerializable - Interface in com.hazelcast.nio.serialization
This interface adds the possibility for the class to act as if it is another class when being deserialized using DataSerializable
TypedStreamDeserializer<T> - Interface in com.hazelcast.nio.serialization
This interface allows deserialization of a binary data with a provided class type.
typeId() - Method in interface com.hazelcast.internal.auditlog.AuditableEvent
 
typeId() - Method in class com.hazelcast.internal.auditlog.impl.NoOpAuditlogService.NoOpEvent
 

U

unassignedSentinel - Variable in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
Sentinel value that marks a slot as "unassigned".
unblacklist(Address) - Method in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
unblacklist(Address) - Method in interface com.hazelcast.internal.cluster.Joiner
Removes an address from the blacklist if it is temporarily blacklisted.
UnblockablePoolExecutorThreadFactory - Class in com.hazelcast.internal.util.executor
This factory is implemented to have a thread factory that creates threads with `UnblockableThread` interface.
UnblockablePoolExecutorThreadFactory(String, ClassLoader) - Constructor for class com.hazelcast.internal.util.executor.UnblockablePoolExecutorThreadFactory
 
UnblockableThread - Interface in com.hazelcast.internal.util.executor
Marker interface for threads that waiting for the responses operations are not allowed.
unblockAcceptEither(Consumer<? super V>, Executor, CompletableFuture<Void>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
unblockApply(Function<? super V, ? extends U>, Executor, InternalCompletableFuture<U>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
unblockApplyToEither(Function<? super V, U>, Executor, CompletableFuture<U>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
unblockCombine(CompletionStage<? extends U>, BiFunction<? super V, ? super U, ? extends R>, Executor, InternalCompletableFuture<R>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
unblockCompose(Function<? super V, ? extends CompletionStage<U>>, Executor, CompletableFuture<U>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
unblockHandle(BiFunction<? super V, Throwable, ? extends U>, Executor, CompletableFuture<U>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
unblockOtherNode(Object, Executor) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
unblockRun(Runnable, Executor, CompletableFuture<Void>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
unblockRunAfterEither(Runnable, Executor, CompletableFuture<Void>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
unblockWhenComplete(BiConsumer<? super V, ? super Throwable>, Executor, CompletableFuture<V>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
UNDEFINED - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
UndefinedErrorCodeException - Exception in com.hazelcast.client
This exception is thrown when an exception that is coming from server is not recognized by the protocol.
UndefinedErrorCodeException(String, String) - Constructor for exception com.hazelcast.client.UndefinedErrorCodeException
 
unescapeSpecialCharacters(String) - Static method in class com.hazelcast.client.impl.statistics.Statistics
 
unescapeSpecialCharacters(String, int) - Static method in class com.hazelcast.client.impl.statistics.Statistics
 
unescapeSpecialCharacters(StringBuilder, int) - Static method in class com.hazelcast.client.impl.statistics.Statistics
 
UNFRAGMENTED_MESSAGE - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
 
UnifiedAggregateEndpointManager - Class in com.hazelcast.internal.nio
 
UnifiedAggregateEndpointManager(TcpIpEndpointManager, Map<EndpointQualifier, EndpointManager<TcpIpConnection>>) - Constructor for class com.hazelcast.internal.nio.UnifiedAggregateEndpointManager
 
UnifiedChannelInitializer - Class in com.hazelcast.internal.nio.tcp
A ChannelInitializer that runs on a member and used for unencrypted channels.
UnifiedChannelInitializer(IOService) - Constructor for class com.hazelcast.internal.nio.tcp.UnifiedChannelInitializer
 
UnifiedProtocolDecoder - Class in com.hazelcast.internal.nio.tcp
A InboundHandler that reads the protocol bytes Protocols and based on the protocol it creates the appropriate handlers.
UnifiedProtocolDecoder(IOService, UnifiedProtocolEncoder) - Constructor for class com.hazelcast.internal.nio.tcp.UnifiedProtocolDecoder
 
UnifiedProtocolEncoder - Class in com.hazelcast.internal.nio.tcp
The ProtocolEncoder is responsible for writing the protocol and once the protocol has been written, the ProtocolEncoder is replaced by the appropriate handler.
UnifiedProtocolEncoder(IOService) - Constructor for class com.hazelcast.internal.nio.tcp.UnifiedProtocolEncoder
 
union(PartitionIdSet) - Method in class com.hazelcast.internal.util.collection.ImmutablePartitionIdSet
 
union(PartitionIdSet) - Method in class com.hazelcast.internal.util.collection.PartitionIdSet
Mutates this PartitionIdSet so it contains the union of this and other's partition IDs.
UNKNOWN - Static variable in class com.hazelcast.version.MemberVersion
UNKNOWN version.
UNKNOWN - Static variable in class com.hazelcast.version.Version
Version 0.0 is UNKNOWN constant UNKNOWN is only equal to itself. is(Less|Greater)Than method with an UNKNOWN operand returns false. is(Less|Greater)OrEqual with an UNKNOWN operand returns false, unless both operands are UNKNOWN. UNKNOWN.isUnknown(Less|Greater)(Than|OrEqual) returns true. otherVersion.isUnknown(Less|Greater)(Than|OrEqual) with an UNKNOWN argument returns false.
UNKNOWN_HAZELCAST_VERSION - Static variable in class com.hazelcast.instance.BuildInfo
 
UNKNOWN_VERSION - Static variable in class com.hazelcast.version.Version
Use 0 as major & minor values for UNKNOWN version
unlock() - Method in class com.hazelcast.client.cp.internal.datastructures.lock.FencedLockProxy
 
unlock(K) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
unlock(K) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
unlock() - Method in class com.hazelcast.cp.internal.datastructures.lock.proxy.AbstractFencedLockProxy
 
unlock() - Method in interface com.hazelcast.cp.lock.FencedLock
Releases the lock if the lock is currently held by the current thread.
unlock(String, String) - Method in interface com.hazelcast.internal.ascii.TextCommandService
 
unlock(String, String) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
 
UNLOCK - Static variable in class com.hazelcast.internal.locksupport.LockDataSerializerHook
 
unlock(NodeEngine, Data) - Method in class com.hazelcast.internal.locksupport.LockProxySupport
 
unlock(Data, UUID, long, long) - Method in interface com.hazelcast.internal.locksupport.LockStore
Unlock a specific key.
unlock(Data, UUID, long, long) - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
unlock(Data, UUID, long, long) - Method in class com.hazelcast.internal.locksupport.LockStoreProxy
 
unlock() - Method in class com.hazelcast.internal.locksupport.operations.UnlockOperation
 
unlock(K) - Method in interface com.hazelcast.map.IMap
Releases the lock for the specified key.
unlock(K) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
unlock(Data, UUID, long, long) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
unlock(Data, UUID, long, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
 
unlock(Data, UUID, long, long) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
unlock(K) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
unlock(K) - Method in interface com.hazelcast.multimap.MultiMap
Releases the lock for the specified key.
UNLOCK_BACKUP - Static variable in class com.hazelcast.internal.locksupport.LockDataSerializerHook
 
UNLOCK_IF_LEASE_EXPIRED - Static variable in class com.hazelcast.internal.locksupport.LockDataSerializerHook
 
UNLOCK_OP - Static variable in class com.hazelcast.cp.internal.datastructures.lock.LockDataSerializerHook
 
UnlockBackupOperation - Class in com.hazelcast.internal.locksupport.operations
 
UnlockBackupOperation() - Constructor for class com.hazelcast.internal.locksupport.operations.UnlockBackupOperation
 
UnlockBackupOperation(ObjectNamespace, Data, long, UUID, boolean) - Constructor for class com.hazelcast.internal.locksupport.operations.UnlockBackupOperation
 
UnlockIfLeaseExpiredOperation - Class in com.hazelcast.internal.locksupport.operations
 
UnlockIfLeaseExpiredOperation() - Constructor for class com.hazelcast.internal.locksupport.operations.UnlockIfLeaseExpiredOperation
 
UnlockIfLeaseExpiredOperation(ObjectNamespace, Data, int) - Constructor for class com.hazelcast.internal.locksupport.operations.UnlockIfLeaseExpiredOperation
 
unlockKey - Variable in class com.hazelcast.map.impl.operation.EvictBackupOperation
 
UnlockMessageTask - Class in com.hazelcast.cp.internal.datastructures.lock.client
Client message task for UnlockOp
UnlockMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.cp.internal.datastructures.lock.client.UnlockMessageTask
 
UnlockOp - Class in com.hazelcast.cp.internal.datastructures.lock.operation
Operation for FencedLock.unlock()
UnlockOp() - Constructor for class com.hazelcast.cp.internal.datastructures.lock.operation.UnlockOp
 
UnlockOp(String, long, long, UUID) - Constructor for class com.hazelcast.cp.internal.datastructures.lock.operation.UnlockOp
 
UnlockOperation - Class in com.hazelcast.internal.locksupport.operations
 
UnlockOperation() - Constructor for class com.hazelcast.internal.locksupport.operations.UnlockOperation
 
UnlockOperation(ObjectNamespace, Data, long) - Constructor for class com.hazelcast.internal.locksupport.operations.UnlockOperation
 
UnlockOperation(ObjectNamespace, Data, long, boolean) - Constructor for class com.hazelcast.internal.locksupport.operations.UnlockOperation
 
UnlockOperation(ObjectNamespace, Data, long, boolean, long) - Constructor for class com.hazelcast.internal.locksupport.operations.UnlockOperation
 
unmarshall(Object) - Method in class com.hazelcast.replicatedmap.impl.record.DataReplicatedRecordStore
 
unmarshall(Object) - Method in class com.hazelcast.replicatedmap.impl.record.ObjectReplicatedRecordStorage
 
unmarshall(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
UNMODIFIABLE_LAZY_LIST - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
 
unmodifiableArray(JsonArray) - Static method in class com.hazelcast.internal.json.JsonArray
Returns an unmodifiable wrapper for the specified JsonArray.
UnmodifiableIterator<E> - Class in com.hazelcast.internal.util
An iterator where items cannot be removed
UnmodifiableIterator() - Constructor for class com.hazelcast.internal.util.UnmodifiableIterator
 
UnmodifiableLazyList<E> - Class in com.hazelcast.spi.impl
 
UnmodifiableLazyList() - Constructor for class com.hazelcast.spi.impl.UnmodifiableLazyList
 
UnmodifiableLazyList(List, SerializationService) - Constructor for class com.hazelcast.spi.impl.UnmodifiableLazyList
 
UnmodifiableListIterator<E> - Class in com.hazelcast.internal.util
A listiterator where items cannot be removed
UnmodifiableListIterator() - Constructor for class com.hazelcast.internal.util.UnmodifiableListIterator
 
unmodifiableObject(JsonObject) - Static method in class com.hazelcast.internal.json.JsonObject
Returns an unmodifiable JsonObject for the specified one.
UNNAMED_NODE - Static variable in interface com.hazelcast.internal.yaml.YamlNode
 
UnorderedIndexStore - Class in com.hazelcast.query.impl
Store indexes out of turn.
UnorderedIndexStore(IndexCopyBehavior) - Constructor for class com.hazelcast.query.impl.UnorderedIndexStore
 
unpark(Notifier) - Method in class com.hazelcast.spi.impl.operationparker.impl.OperationParkerImpl
 
unpark(Notifier, WaitNotifyKey) - Method in class com.hazelcast.spi.impl.operationparker.impl.WaitSet
 
unpark(Notifier) - Method in interface com.hazelcast.spi.impl.operationparker.OperationParker
Unparks the parked BlockingOperation operation by rescheduling it on the OperationExecutor A parked operation registered with the Notifier.getNotifiedKey() will be notified and deregistered.
unregister(HazelcastMBean) - Static method in class com.hazelcast.internal.jmx.HazelcastMBean
 
unregister() - Method in class com.hazelcast.spi.impl.tenantcontrol.NoopTenantControl
 
unregister() - Method in interface com.hazelcast.spi.tenantcontrol.TenantControl
To be called when the Hazelcast object attached to this tenant is destroyed.
unregisterCacheObject(String, String, boolean) - Static method in class com.hazelcast.cache.impl.MXBeanUtil
UnRegisters the mxbean if registered already.
UNSAFE - Static variable in class com.hazelcast.internal.memory.impl.UnsafeUtil
The Unsafe instance which is available and ready to use.
UNSAFE_AVAILABLE - Static variable in class com.hazelcast.internal.memory.impl.UnsafeUtil
If this constant is true, then UnsafeUtil.UNSAFE refers to a usable Unsafe instance.
UNSAFE_MODE_PARTITION_STATE - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
UNSAFE_RAFT_BACKUP_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
UNSAFE_RAFT_QUERY_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
UNSAFE_RAFT_REPLICATE_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
UNSAFE_SNAPSHOT_REPLICATE_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
UNSAFE_STATE_REPLICATE_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
UnsafeModePartitionState - Class in com.hazelcast.cp.internal
State for RaftService used in UNSAFE mode.
UnsafeModePartitionState() - Constructor for class com.hazelcast.cp.internal.UnsafeModePartitionState
 
UnsafeRaftBackupOp - Class in com.hazelcast.cp.internal.operation.unsafe
Partition-based backup operation for Raft services to be executed in UNSAFE mode.
UnsafeRaftBackupOp() - Constructor for class com.hazelcast.cp.internal.operation.unsafe.UnsafeRaftBackupOp
 
UnsafeRaftBackupOp(CPGroupId, RaftOp) - Constructor for class com.hazelcast.cp.internal.operation.unsafe.UnsafeRaftBackupOp
 
UnsafeRaftQueryOp - Class in com.hazelcast.cp.internal.operation.unsafe
Partition-based Raft query operation for Raft services to be executed in UNSAFE mode.
UnsafeRaftQueryOp() - Constructor for class com.hazelcast.cp.internal.operation.unsafe.UnsafeRaftQueryOp
 
UnsafeRaftQueryOp(CPGroupId, RaftOp) - Constructor for class com.hazelcast.cp.internal.operation.unsafe.UnsafeRaftQueryOp
 
UnsafeRaftReplicateOp - Class in com.hazelcast.cp.internal.operation.unsafe
Partition-based Raft replicate operation for Raft services to be executed in UNSAFE mode.
UnsafeRaftReplicateOp() - Constructor for class com.hazelcast.cp.internal.operation.unsafe.UnsafeRaftReplicateOp
 
UnsafeRaftReplicateOp(CPGroupId, RaftOp) - Constructor for class com.hazelcast.cp.internal.operation.unsafe.UnsafeRaftReplicateOp
 
UnsafeSnapshotReplicationOp - Class in com.hazelcast.cp.internal.operation.unsafe
Partition-based replication operation for Raft services to be executed in UNSAFE mode.
UnsafeSnapshotReplicationOp() - Constructor for class com.hazelcast.cp.internal.operation.unsafe.UnsafeSnapshotReplicationOp
 
UnsafeSnapshotReplicationOp(Map<CPGroupId, Object>) - Constructor for class com.hazelcast.cp.internal.operation.unsafe.UnsafeSnapshotReplicationOp
 
UnsafeStateReplicationOp - Class in com.hazelcast.cp.internal.operation.unsafe
Partition-based replication operation to migrate RaftService's state in UNSAFE mode.
UnsafeStateReplicationOp() - Constructor for class com.hazelcast.cp.internal.operation.unsafe.UnsafeStateReplicationOp
 
UnsafeStateReplicationOp(UnsafeModePartitionState) - Constructor for class com.hazelcast.cp.internal.operation.unsafe.UnsafeStateReplicationOp
 
UnsafeUtil - Class in com.hazelcast.internal.memory.impl
Utility class for Unsafe.
UNSUPPORTED_CALLBACK - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
UNSUPPORTED_OPERATION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
unwrap(Class<T>) - Method in class com.hazelcast.cache.impl.CacheEntry
 
unwrap(Class<T>) - Method in class com.hazelcast.cache.impl.CacheEntryEventImpl
 
unwrap(Class<T>) - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
unwrap(Class<T>) - Method in class com.hazelcast.cache.impl.CacheProxy
 
unwrap(Class<T>) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
 
unwrap(Class<T>) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
unwrap(Class<T>) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
 
unwrap(Class<T>) - Method in class com.hazelcast.internal.nearcache.impl.DefaultNearCache
 
unwrap(Class<T>) - Method in interface com.hazelcast.internal.nearcache.NearCache
Used to access non-standard methods of an implementation.
unwrap(Class<T>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
 
unwrapIfOptional(Object) - Static method in class com.hazelcast.query.impl.predicates.PredicateUtils
Unwraps the given potentially optional value.
update(int) - Method in class com.hazelcast.monitor.impl.LocalFlakeIdGeneratorStatsImpl
 
update() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
update(Object, Object, QueryableEntry, IndexOperationStats) - Method in class com.hazelcast.query.impl.BaseIndexStore
 
update(Object, Object, QueryableEntry, IndexOperationStats) - Method in interface com.hazelcast.query.impl.IndexStore
Updates the existing entry mapping in this index by remapping it from the given old value to the new given value.
UPDATE_MANAGEMENT_CENTER_URL - Static variable in class com.hazelcast.internal.management.ManagementDataSerializerHook
 
UPDATE_MAP_CONFIG - Static variable in class com.hazelcast.internal.management.ManagementDataSerializerHook
 
UPDATE_PERMISSION_CONFIG_OPERATION - Static variable in class com.hazelcast.internal.management.ManagementDataSerializerHook
 
UPDATE_RAFT_GROUP_MEMBERS_COMMAND - Static variable in class com.hazelcast.cp.internal.raft.impl.RaftDataSerializerHook
 
UPDATE_STARTED - Static variable in interface com.hazelcast.internal.nearcache.NearCacheRecord
 
updateAccessDuration(Data, R, ExpiryPolicy, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
updateAdd(Object, Object) - Method in class com.hazelcast.wan.impl.merkletree.ArrayMerkleTree
 
updateAdd(Object, Object) - Method in interface com.hazelcast.wan.impl.merkletree.MerkleTree
Updating the tree with adding a new entry to the tree
updateAndGet(LocalMapStatsImpl) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
 
updateAndGetReserved(K, V, long, boolean) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
updateAndGetReserved(K, V, long, boolean) - Method in class com.hazelcast.internal.nearcache.impl.store.BaseHeapNearCacheRecordStore
 
updateAttribute(MemberAttributeOperationType, String, String) - Method in class com.hazelcast.cluster.impl.AbstractMember
 
updateClientName(String) - Method in class com.hazelcast.client.impl.clientside.ClientLoggingService
 
updateCostEstimate(long) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
updated - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicLongCompareAndSetCodec.RequestParameters
The new value
updateExpiryPolicyOfRecord(Data, R, Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
updateGetAndPutStat(boolean, boolean, boolean, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
updateGroupMembers(long, Collection<RaftEndpoint>) - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
Updates Raft group members.
updateGroupMembers(long, Collection<RaftEndpoint>) - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Initializes the last applied group members with the members and logIndex.
updateIndexStats(Map<String, OnDemandIndexStats>) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
 
updateIntervalSec - Variable in class com.hazelcast.internal.jmx.HazelcastMBean
 
updateInvocationManagerMembers(long, long, Collection<CPMemberInfo>) - Method in class com.hazelcast.cp.internal.RaftService
 
updateLastAppendEntriesTimestamp() - Method in class com.hazelcast.cp.internal.raft.impl.RaftNodeImpl
 
updateLastKnownStaleSequence(MetaDataContainer, int) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.RepairingHandler
 
updateLoadStatus(boolean, Throwable) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
 
updateLoadStatus(boolean, Throwable) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
Advances the state of the map key loader for this partition and sets the key loading future result if the lastBatch is true.
updateManagementCenterUrl(String) - Method in class com.hazelcast.internal.management.ManagementCenterService
 
UpdateManagementCenterUrlOperation - Class in com.hazelcast.internal.management.operation
Operation to update Management Center URL configured on the node.
UpdateManagementCenterUrlOperation() - Constructor for class com.hazelcast.internal.management.operation.UpdateManagementCenterUrlOperation
 
UpdateManagementCenterUrlOperation(String) - Constructor for class com.hazelcast.internal.management.operation.UpdateManagementCenterUrlOperation
 
UpdateMapConfigOperation - Class in com.hazelcast.internal.management.operation
Operation to update map configuration from Management Center.
UpdateMapConfigOperation() - Constructor for class com.hazelcast.internal.management.operation.UpdateMapConfigOperation
 
UpdateMapConfigOperation(String, MapConfig) - Constructor for class com.hazelcast.internal.management.operation.UpdateMapConfigOperation
 
updateMember(CPMemberInfo) - Method in class com.hazelcast.spi.impl.operationservice.impl.RaftInvocationContext
 
updateMemberAttribute(UUID, MemberAttributeOperationType, String, String) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
updateMembers(MembersView, Address, UUID, UUID) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
 
updatePartitionReplicaVersions(int, ServiceNamespace, long[], int) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
 
updatePartitionReplicaVersions(int, ServiceNamespace, long[], int) - Method in interface com.hazelcast.internal.partition.PartitionReplicaVersionManager
Updates the partition replica version and triggers replica sync if the replica is dirty (e.g.
UpdatePermissionConfigOperation - Class in com.hazelcast.internal.management.operation
Propagates PermissionConfig changes to members.
UpdatePermissionConfigOperation() - Constructor for class com.hazelcast.internal.management.operation.UpdatePermissionConfigOperation
 
UpdatePermissionConfigOperation(Set<PermissionConfig>) - Constructor for class com.hazelcast.internal.management.operation.UpdatePermissionConfigOperation
 
UpdatePermissionConfigRequest - Class in com.hazelcast.internal.management.request
Helper class to serialize/deserialize client permission update requests.
UpdatePermissionConfigRequest() - Constructor for class com.hazelcast.internal.management.request.UpdatePermissionConfigRequest
 
UpdatePermissionConfigRequest(Set<PermissionConfig>) - Constructor for class com.hazelcast.internal.management.request.UpdatePermissionConfigRequest
 
UpdateRaftGroupMembersCmd - Class in com.hazelcast.cp.internal.raft.impl.command
A RaftGroupCmd to update members of an existing Raft group.
UpdateRaftGroupMembersCmd() - Constructor for class com.hazelcast.cp.internal.raft.impl.command.UpdateRaftGroupMembersCmd
 
UpdateRaftGroupMembersCmd(Collection<RaftEndpoint>, RaftEndpoint, MembershipChangeMode) - Constructor for class com.hazelcast.cp.internal.raft.impl.command.UpdateRaftGroupMembersCmd
 
updateRecord(Data, CacheRecord, long, long, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
updateRecord(Data, R, Object, long, long, boolean, int, UUID, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
updateRecordValue(R, Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
updateRecordValue(R, V) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
updateRecordValue(NearCacheDataRecord, V) - Method in class com.hazelcast.internal.nearcache.impl.store.NearCacheDataRecordStore
 
updateRecordValue(NearCacheObjectRecord<V>, V) - Method in class com.hazelcast.internal.nearcache.impl.store.NearCacheObjectRecordStore
 
updateRecordValue(K, R, Object) - Method in interface com.hazelcast.map.impl.recordstore.Storage
 
updateRecordValue(Data, R, Object) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
updateRecordWithExpiry(Data, Object, R, long, long, boolean, int, UUID, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
updateRecordWithExpiry(Data, Object, R, long, long, boolean, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
updateRecordWithExpiry(Data, Object, R, long, long, boolean, int, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
updateRecordWithExpiry(Data, Object, R, ExpiryPolicy, long, boolean, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
updateRecordWithExpiry(Data, Object, R, ExpiryPolicy, long, boolean, int, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
updateRecordWithExpiry(Data, Object, R, ExpiryPolicy, long, boolean, int, UUID, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
updateRecordWithExpiry(Data, CacheRecord, ExpiryPolicy, long, UUID) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
updateRemove(Object, Object) - Method in class com.hazelcast.wan.impl.merkletree.ArrayMerkleTree
 
updateRemove(Object, Object) - Method in interface com.hazelcast.wan.impl.merkletree.MerkleTree
Updating the tree with removing an entry
updateReplace(Object, Object, Object) - Method in class com.hazelcast.wan.impl.merkletree.ArrayMerkleTree
 
updateReplace(Object, Object, Object) - Method in interface com.hazelcast.wan.impl.merkletree.MerkleTree
Updating the tree with replacing an old value with a new one
updateReplaceStat(boolean, boolean, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
updateReservedRecordInternal(K, V, R, long) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore
 
updateStatistics() - Method in class com.hazelcast.client.impl.proxy.ClientReliableMessageRunner
 
updateStatistics() - Method in class com.hazelcast.topic.impl.reliable.MessageRunner
 
updateStatistics() - Method in class com.hazelcast.topic.impl.reliable.ReliableMessageRunner
 
updateStatsForBatch(String, int) - Method in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorService
Updated the statistics for the FlakeIdGenerator with the given name for a newly generated batch of the given size.
upperCaseInternal(String) - Static method in class com.hazelcast.internal.util.StringUtil
HC specific settings, operands etc.
urgent - Variable in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
 
UrgentMessageTask - Interface in com.hazelcast.client.impl.protocol.task
 
UrgentSystemOperation - Interface in com.hazelcast.spi.impl.operationservice
An Marker interface that signals that an operation is an urgent System Operation.
uri - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
uri - Variable in class com.hazelcast.internal.ascii.rest.HttpCommand
 
URI_ADD_WAN_CONFIG - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_CHANGE_CLUSTER_STATE_URL - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_CLUSTER - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_CLUSTER_MANAGEMENT_BASE_URL - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_CLUSTER_NODES_URL - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_CLUSTER_STATE_URL - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_CLUSTER_VERSION_URL - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_CP_GROUPS_URL - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_CP_MEMBERS_URL - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_CP_SESSIONS_SUFFIX - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_CP_SUBSYSTEM_BASE_URL - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_FORCESTART_CLUSTER_URL - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_HEALTH_READY - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_HEALTH_URL - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_HOT_RESTART_BACKUP_CLUSTER_URL - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_HOT_RESTART_BACKUP_INTERRUPT_CLUSTER_URL - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_INSTANCE - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_LICENSE_INFO - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_LOCAL_CP_MEMBER_URL - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_MANCENTER_BASE_URL - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_MANCENTER_CHANGE_URL - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_MANCENTER_WAN_CLEAR_QUEUES - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_MAPS - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_PARTIALSTART_CLUSTER_URL - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_QUEUES - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_REMOVE_SUFFIX - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_RESTART_CP_SUBSYSTEM_URL - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_SHUTDOWN_CLUSTER_URL - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_SHUTDOWN_NODE_CLUSTER_URL - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_SYNTAX - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
URI_UPDATE_PERMISSIONS - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_WAN_CONSISTENCY_CHECK_MAP - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_WAN_PAUSE_PUBLISHER - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_WAN_RESUME_PUBLISHER - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_WAN_STOP_PUBLISHER - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_WAN_SYNC_ALL_MAPS - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
URI_WAN_SYNC_MAP - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommandProcessor
 
UrlXmlConfig - Class in com.hazelcast.config
A Config which is loaded using some url pointing to a Hazelcast XML file.
UrlXmlConfig(String) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the XML.
UrlXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url.
UrlXmlConfig(URL) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the XML.
UrlXmlConfig(URL, Properties) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url.
UrlYamlConfig - Class in com.hazelcast.config
A Config which is loaded using some url pointing to a Hazelcast YAML file.
UrlYamlConfig(String) - Constructor for class com.hazelcast.config.UrlYamlConfig
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the YAML.
UrlYamlConfig(String, Properties) - Constructor for class com.hazelcast.config.UrlYamlConfig
Creates new Config which is loaded from the given url.
UrlYamlConfig(URL) - Constructor for class com.hazelcast.config.UrlYamlConfig
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the YAML.
UrlYamlConfig(URL, Properties) - Constructor for class com.hazelcast.config.UrlYamlConfig
Creates new Config which is loaded from the given url.
USE_LEGACY_MEMBER_LIST_FORMAT - Static variable in class com.hazelcast.spi.properties.GroupProperty
Enables legacy (pre-3.9) member list format which is printed in logs.
usedMemory(Runtime) - Static method in class com.hazelcast.internal.util.JVMUtil
Returns used memory as reported by the Runtime and the function (totalMemory - freeMemory) It attempts to correct atomicity issues (ie.
useNativeByteOrder - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
USER_CODE_DEPLOYMENT_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
USER_CODE_DEPLOYMENT_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
USER_EXCEPTIONS_RANGE_START - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
These codes onwards are reserved to be used by the end-user
UserCodeDeploymentClassLoader - Class in com.hazelcast.internal.usercodedeployment
 
UserCodeDeploymentClassLoader(ClassLoader) - Constructor for class com.hazelcast.internal.usercodedeployment.UserCodeDeploymentClassLoader
 
UserCodeDeploymentConfig - Class in com.hazelcast.config
Configuration of User Code Deployment.
UserCodeDeploymentConfig() - Constructor for class com.hazelcast.config.UserCodeDeploymentConfig
 
UserCodeDeploymentConfig.ClassCacheMode - Enum in com.hazelcast.config
Controls caching of classes loaded from remote members
UserCodeDeploymentConfig.ProviderMode - Enum in com.hazelcast.config
Controls how to react to receiving a classloading request from a remote member
UserCodeDeploymentPermission - Class in com.hazelcast.security.permission
 
UserCodeDeploymentPermission(String...) - Constructor for class com.hazelcast.security.permission.UserCodeDeploymentPermission
 
UserCodeDeploymentSerializerHook - Class in com.hazelcast.internal.usercodedeployment.impl
 
UserCodeDeploymentSerializerHook() - Constructor for class com.hazelcast.internal.usercodedeployment.impl.UserCodeDeploymentSerializerHook
 
UserCodeDeploymentService - Class in com.hazelcast.internal.usercodedeployment
 
UserCodeDeploymentService() - Constructor for class com.hazelcast.internal.usercodedeployment.UserCodeDeploymentService
 
username - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec.RequestParameters
Name of the user for authentication.
USERNAME_PWD_CRED - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
 
UsernamePasswordCredentials - Class in com.hazelcast.security
Simple implementation of PasswordCredentials using name and password as security attributes.
UsernamePasswordCredentials() - Constructor for class com.hazelcast.security.UsernamePasswordCredentials
 
UsernamePasswordCredentials(String, String) - Constructor for class com.hazelcast.security.UsernamePasswordCredentials
 
UsernamePasswordIdentityConfig - Class in com.hazelcast.config.security
Simple username/password identity configuration.
UsernamePasswordIdentityConfig(String, String) - Constructor for class com.hazelcast.config.security.UsernamePasswordIdentityConfig
 
usesCachedQueryableEntries(boolean) - Method in class com.hazelcast.query.impl.Indexes.Builder
 
UTF8_CHARSET - Static variable in class com.hazelcast.internal.util.StringUtil
UTF-8 Charset
UTF_8 - Static variable in class com.hazelcast.internal.nio.Bits
A reusable instance of the UTF-8 charset
UTF_BUFFER_SIZE - Static variable in interface com.hazelcast.internal.nio.BufferObjectDataInput
 
UTF_BUFFER_SIZE - Static variable in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
UTF_DATA_FORMAT - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
uuid - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec.RequestParameters
Unique string identifying the connected client uniquely.
uuid - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCodec.ResponseParameters
Unique string identifying the connected client uniquely.
uuid - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec.RequestParameters
Unique string identifying the connected client uniquely.
uuid - Variable in class com.hazelcast.client.impl.protocol.codec.ClientAuthenticationCustomCodec.ResponseParameters
Unique string identifying the connected client uniquely.
uuid - Variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnAddressCodec.RequestParameters
Unique id for the execution.
uuid - Variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceCancelOnPartitionCodec.RequestParameters
Unique id for the execution.
uuid - Variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToAddressCodec.RequestParameters
Unique id for the execution.
uuid - Variable in class com.hazelcast.client.impl.protocol.codec.ExecutorServiceSubmitToPartitionCodec.RequestParameters
Unique id for the execution.
uuid - Variable in class com.hazelcast.client.impl.protocol.codec.MetricsReadMetricsCodec.RequestParameters
The UUID of the member that is supposed to read the metrics from.
uuid - Variable in class com.hazelcast.cluster.impl.AbstractMember
 
uuid(UUID) - Method in class com.hazelcast.cluster.impl.MemberImpl.Builder
 
uuid - Variable in class com.hazelcast.internal.cluster.impl.JoinMessage
 
uuid - Variable in class com.hazelcast.internal.management.dto.ClientEndPointDTO
 
uuid - Variable in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
uuid() - Method in class com.hazelcast.internal.partition.PartitionReplica
 
UUID_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
UUID_FILTER - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
UUID_SIZE_IN_BYTES - Static variable in class com.hazelcast.client.impl.protocol.codec.builtin.FixedSizeTypesCodec
 
UuidFilter - Class in com.hazelcast.map.impl.nearcache.invalidation
Compares supplied UUID with this filters' UUID to prevent unneeded delivery of an invalidation event to operation caller.
UuidFilter() - Constructor for class com.hazelcast.map.impl.nearcache.invalidation.UuidFilter
 
UuidFilter(UUID) - Constructor for class com.hazelcast.map.impl.nearcache.invalidation.UuidFilter
 
UUIDSerializationUtil - Class in com.hazelcast.internal.util
Util methods for UUID serialization / deserialization operations.
UuidSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.UuidSerializer
 
UuidUtil - Class in com.hazelcast.internal.util
Util class to generate type 4 (pseudo randomly generated) UUID.

V

V3_10 - Static variable in class com.hazelcast.internal.cluster.Versions
Represents cluster version 3.10
V3_11 - Static variable in class com.hazelcast.internal.cluster.Versions
Represents cluster version 3.11
V3_12 - Static variable in class com.hazelcast.internal.cluster.Versions
Represents cluster version 3.12
V3_8 - Static variable in class com.hazelcast.internal.cluster.Versions
Represents cluster version 3.8
V3_9 - Static variable in class com.hazelcast.internal.cluster.Versions
Represents cluster version 3.9
V4_0 - Static variable in class com.hazelcast.internal.cluster.Versions
Represents cluster version 4.0
validate() - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
validate(T) - Method in interface com.hazelcast.config.properties.ValueValidator
Validates the given value according to the defined validation logic and throws a ValidationException if configuration does not meet the requirements or logical errors are spotted.
validate() - Method in class com.hazelcast.internal.cluster.impl.ClusterStateChange
 
validateAndNormalize(String, IndexConfig) - Static method in class com.hazelcast.query.impl.IndexUtils
Validate provided index config and normalize it's name and attribute names.
validateAttribute(IndexConfig, String) - Static method in class com.hazelcast.query.impl.IndexUtils
Validate attribute name.
validateAttribute(String) - Static method in class com.hazelcast.query.impl.IndexUtils
Validate attribute name.
validateCacheConfig(CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
validateCacheConfig(CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
 
validateCacheConfig(CacheConfig<K, V>) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
 
validateConfiguredKeyType(Class<K>, K) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
Validates the key with key type.
validateConfiguredTypes(CacheConfig, K) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
Validates that the configured key matches the provided key.
validateConfiguredTypes(CacheConfig, K, V) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
Validates the configured key and value types matches the provided key, value types.
validateConfiguredTypes(CacheConfig, K, V, V) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
Validates the configured key and value types matches the provided key, value types.
validateConfiguredValueType(Class<V>, V) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
Validates the value with value type.
validateJoinMessage(JoinMessage) - Method in class com.hazelcast.internal.cluster.impl.ClusterJoinManager
Validate that the configuration received from the remote node in joinMessage is compatible with the configuration of this node.
validateJoinRequest(JoinMessage) - Method in class com.hazelcast.instance.impl.DefaultNodeExtension
 
validateJoinRequest(JoinMessage) - Method in interface com.hazelcast.instance.impl.NodeExtension
Executed on the master node before allowing a new member to join from ClusterJoinManager.handleJoinRequest(JoinRequest, Connection).
validateMigrationStamp(int) - Method in class com.hazelcast.map.impl.MapService
 
validateMigrationStamp(int) - Method in class com.hazelcast.spi.impl.CountingMigrationAwareService
Returns true if there's no primary replica migrations started and/or completed since issuance of the given stamp.
validateNotNull(K) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
Validates that a key is not null.
validateNotNull(K, V) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
Validates that key, value pair are both not null.
validateNotNull(K, V, V) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
Validates that key and multi values are not null.
validateNotNull(Set<? extends K>) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
Validates supplied set is not null.
validateNotNull(Map<? extends K, ? extends V>) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
This validator ensures that no key or value is null in the provided map.
validateResults(Map<Integer, Object>) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
Cache clear response validator, loop on results to validate that no exception exists on the result map.
validatesTarget() - Method in class com.hazelcast.cp.internal.operation.GetLeadedGroupsOp
 
validatesTarget() - Method in class com.hazelcast.cp.internal.operation.integration.AsyncRaftOp
 
validatesTarget() - Method in class com.hazelcast.cp.internal.operation.RaftQueryOp
 
validatesTarget() - Method in class com.hazelcast.cp.internal.operation.RaftReplicateOp
 
validatesTarget() - Method in class com.hazelcast.cp.internal.operation.RestartCPMemberOp
 
validatesTarget() - Method in class com.hazelcast.cp.internal.operation.TransferLeadershipOp
 
validatesTarget() - Method in class com.hazelcast.internal.cluster.impl.operations.OnJoinOp
 
validatesTarget() - Method in class com.hazelcast.internal.partition.operation.FinalizeMigrationOperation
 
validatesTarget() - Method in class com.hazelcast.internal.partition.operation.PartitionBackupReplicaAntiEntropyOperation
 
validatesTarget() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRequest
 
validatesTarget() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncResponse
 
validatesTarget() - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRetryResponse
 
validatesTarget() - Method in class com.hazelcast.map.impl.operation.MapPartitionDestroyOperation
 
validatesTarget() - Method in class com.hazelcast.replicatedmap.impl.operation.EvictionOperation
 
validatesTarget() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
 
validatesTarget() - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
validateSuffixInSystemProperty(String) - Static method in class com.hazelcast.internal.config.DeclarativeConfigUtil
Validates if the config file referenced in propertyKey has an accepted suffix.
ValidationException - Exception in com.hazelcast.config.properties
This exception is thrown from ValueValidator implementations whenever the validation has not succeed for any reason.
ValidationException(String) - Constructor for exception com.hazelcast.config.properties.ValidationException
 
ValidationException(String, Throwable) - Constructor for exception com.hazelcast.config.properties.ValidationException
 
ValidationException(Throwable) - Constructor for exception com.hazelcast.config.properties.ValidationException
 
validator() - Method in interface com.hazelcast.config.properties.PropertyDefinition
Returns an optional validator to validate a value before finalizing the configuration.
validator() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
 
value - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
value - Variable in class com.hazelcast.cache.impl.record.CacheObjectRecord
 
value - Variable in class com.hazelcast.client.impl.protocol.codec.AtomicRefContainsCodec.RequestParameters
The value to check (is allowed to be null).
value - Variable in class com.hazelcast.client.impl.protocol.codec.CacheGetAndReplaceCodec.RequestParameters
The new value to be associated with the specified key.
value - Variable in class com.hazelcast.client.impl.protocol.codec.CachePutCodec.RequestParameters
The value to be associated with the key.
value - Variable in class com.hazelcast.client.impl.protocol.codec.CachePutIfAbsentCodec.RequestParameters
The value that has the specified key associated with it.
value - Variable in class com.hazelcast.client.impl.protocol.codec.ListAddCodec.RequestParameters
Element to be appended to this list
value - Variable in class com.hazelcast.client.impl.protocol.codec.ListAddWithIndexCodec.RequestParameters
Value to be inserted.
value - Variable in class com.hazelcast.client.impl.protocol.codec.ListContainsCodec.RequestParameters
Element whose presence in this list is to be tested
value - Variable in class com.hazelcast.client.impl.protocol.codec.ListIndexOfCodec.RequestParameters
Element to search for
value - Variable in class com.hazelcast.client.impl.protocol.codec.ListLastIndexOfCodec.RequestParameters
Element to search for
value - Variable in class com.hazelcast.client.impl.protocol.codec.ListRemoveCodec.RequestParameters
Element to be removed from this list, if present
value - Variable in class com.hazelcast.client.impl.protocol.codec.ListSetCodec.RequestParameters
Element to be stored at the specified position
value - Variable in class com.hazelcast.client.impl.protocol.codec.MapContainsValueCodec.RequestParameters
Value to check if exists in the map.
value - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutCodec.RequestParameters
Value for the map entry.
value - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentCodec.RequestParameters
New value for the map entry.
value - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutIfAbsentWithMaxIdleCodec.RequestParameters
Value for the map entry.
value - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutTransientCodec.RequestParameters
New value for the map entry.
value - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutTransientWithMaxIdleCodec.RequestParameters
Value for the map entry.
value - Variable in class com.hazelcast.client.impl.protocol.codec.MapPutWithMaxIdleCodec.RequestParameters
Value for the map entry.
value - Variable in class com.hazelcast.client.impl.protocol.codec.MapRemoveIfSameCodec.RequestParameters
Test the existing value against this value to find if equal to this value.
value - Variable in class com.hazelcast.client.impl.protocol.codec.MapReplaceCodec.RequestParameters
New value for the map entry.
value - Variable in class com.hazelcast.client.impl.protocol.codec.MapReplaceIfSameCodec.RequestParameters
New value for the map entry.
value - Variable in class com.hazelcast.client.impl.protocol.codec.MapSetCodec.RequestParameters
New value for the map entry.
value - Variable in class com.hazelcast.client.impl.protocol.codec.MapSetWithMaxIdleCodec.RequestParameters
Value for the map entry.
value - Variable in class com.hazelcast.client.impl.protocol.codec.MapTryPutCodec.RequestParameters
New value for the map entry.
value - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsEntryCodec.RequestParameters
The value whose existence is checked.
value - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapContainsValueCodec.RequestParameters
The value whose existence is checked.
value - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapPutCodec.RequestParameters
The value to be stored
value - Variable in class com.hazelcast.client.impl.protocol.codec.MultiMapRemoveEntryCodec.RequestParameters
The value of the entry to remove
value - Variable in class com.hazelcast.client.impl.protocol.codec.PNCounterAddCodec.ResponseParameters
TODO DOC
value - Variable in class com.hazelcast.client.impl.protocol.codec.PNCounterGetCodec.ResponseParameters
TODO DOC
value - Variable in class com.hazelcast.client.impl.protocol.codec.QueueContainsCodec.RequestParameters
Element whose presence in this collection is to be tested
value - Variable in class com.hazelcast.client.impl.protocol.codec.QueueOfferCodec.RequestParameters
The element to add
value - Variable in class com.hazelcast.client.impl.protocol.codec.QueuePutCodec.RequestParameters
The element to add
value - Variable in class com.hazelcast.client.impl.protocol.codec.QueueRemoveCodec.RequestParameters
Element to be removed from this queue, if present
value - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapContainsValueCodec.RequestParameters
value whose presence in this map is to be tested
value - Variable in class com.hazelcast.client.impl.protocol.codec.ReplicatedMapPutCodec.RequestParameters
Value to be associated with the specified key
value - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferAddCodec.RequestParameters
to item to add
value - Variable in class com.hazelcast.client.impl.protocol.codec.SetAddCodec.RequestParameters
Element to be added to this set
value - Variable in class com.hazelcast.client.impl.protocol.codec.SetContainsCodec.RequestParameters
Element whose presence in this set is to be tested
value - Variable in class com.hazelcast.client.impl.protocol.codec.SetRemoveCodec.RequestParameters
Object to be removed from this set, if present
value - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapContainsValueCodec.RequestParameters
The specified value.
value - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutCodec.RequestParameters
The value to associate with the key.
value - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapPutIfAbsentCodec.RequestParameters
The value to associate with the key when there is no previous value.
value - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapRemoveIfSameCodec.RequestParameters
Remove the key if it has this value.
value - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapReplaceCodec.RequestParameters
The value replaced the previous value
value - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMapSetCodec.RequestParameters
The value to associate with key
value - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapPutCodec.RequestParameters
The value to be stored
value - Variable in class com.hazelcast.client.impl.protocol.codec.TransactionalMultiMapRemoveEntryCodec.RequestParameters
The value to be stored
value - Variable in class com.hazelcast.collection.impl.collection.CollectionItem
 
value - Variable in class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
 
value - Variable in class com.hazelcast.core.EntryEvent
 
value() - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLong
 
value() - Method in enum com.hazelcast.cp.internal.datastructures.atomiclong.operation.AlterOp.AlterResultType
 
value() - Method in enum com.hazelcast.cp.internal.datastructures.atomicref.operation.ApplyOp.ReturnValueType
 
value(int) - Static method in class com.hazelcast.internal.json.Json
Returns a JsonValue instance that represents the given int value.
value(long) - Static method in class com.hazelcast.internal.json.Json
Returns a JsonValue instance that represents the given long value.
value(float) - Static method in class com.hazelcast.internal.json.Json
Returns a JsonValue instance that represents the given float value.
value(double) - Static method in class com.hazelcast.internal.json.Json
Returns a JsonValue instance that represents the given double value.
value(String) - Static method in class com.hazelcast.internal.json.Json
Returns a JsonValue instance that represents the given string.
value(boolean) - Static method in class com.hazelcast.internal.json.Json
Returns a JsonValue instance that represents the given boolean value.
value - Variable in class com.hazelcast.internal.management.dto.ClientBwListEntryDTO
 
value - Variable in class com.hazelcast.internal.nearcache.impl.record.AbstractNearCacheRecord
 
value() - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap.LongLongCursor
 
value() - Method in interface com.hazelcast.internal.util.collection.LongCursor
 
value() - Method in interface com.hazelcast.internal.util.collection.LongLongCursor
 
value - Variable in class com.hazelcast.internal.util.ConcurrentReferenceHashMap.SimpleEntry
 
value - Variable in class com.hazelcast.internal.util.MutableInteger
Mutable integer value of this instance.
value - Variable in class com.hazelcast.internal.util.MutableLong
Mutable long value of this instance.
value - Variable in class com.hazelcast.internal.util.SampleableConcurrentHashMap.SamplingEntry
 
value - Variable in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
 
value() - Method in enum com.hazelcast.query.QueryConstants
 
value - Variable in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
 
VALUE_SIZE_GRANULARITY - Static variable in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
VALUE_SPACE - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
 
valueAddr2slotBase(long) - Static method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyImpl
 
valueAddress() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotCursor
 
valueAddress() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase.Cursor
 
ValueCallback<T> - Interface in com.hazelcast.query.extractor
Enables notifying about values extracted in a ValueExtractor
ValueCollectionFactory - Class in com.hazelcast.multimap.impl
MultiMap values are backed by collections which are created by static factory methods in this class.
ValueCollector<T> - Interface in com.hazelcast.query.extractor
Enables collecting values extracted in a ValueExtractor
valueComparator - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
ValueComparator - Interface in com.hazelcast.internal.util.comparators
Comparator contract for stored values.
ValueComparatorUtil - Class in com.hazelcast.internal.util.comparators
Utility class to get comparators by InMemoryFormat of stored values.
valueCount(K) - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
valueCount(K) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMultiMapProxy
 
valueCount(K) - Method in interface com.hazelcast.multimap.BaseMultiMap
Returns the number of values matching the given key in the multimap.
valueCount(K) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
valueCount(K) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
 
valueCount(K) - Method in interface com.hazelcast.multimap.MultiMap
Returns the number of values that match the given key in the multimap.
valueCount(K) - Method in interface com.hazelcast.transaction.TransactionalMultiMap
Returns the number of values matching the given key in the multimap.
valueData - Variable in class com.hazelcast.query.impl.CachedQueryEntry
 
ValueExtractor<T,A> - Interface in com.hazelcast.query.extractor
Common superclass for all extractors that enable the user to define custom attributes and extract their values.
valueLengthValid(int) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyImpl
 
valueLengthValid(int) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyNoValue
 
valueList - Variable in class com.hazelcast.client.impl.protocol.codec.ListAddAllCodec.RequestParameters
Collection containing elements to be added to this list
valueList - Variable in class com.hazelcast.client.impl.protocol.codec.ListAddAllWithIndexCodec.RequestParameters
The list of value to insert into the list.
valueList - Variable in class com.hazelcast.client.impl.protocol.codec.RingbufferAddAllCodec.RequestParameters
the batch of items to add
valueList - Variable in class com.hazelcast.client.impl.protocol.codec.SetAddAllCodec.RequestParameters
Collection containing elements to be added to this set
valueList - Variable in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
 
valueLoaded - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
valueMap - Variable in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllBackupOperation
 
valueMap - Variable in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
 
valueMap - Variable in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
 
valueObject - Variable in class com.hazelcast.query.impl.CachedQueryEntry
 
valueOf(String) - Static method in enum com.hazelcast.cache.CacheEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cache.impl.CacheEntryProcessorEntry.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cache.impl.CacheEntryViews.CacheEntryViewType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.client.ClientType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.client.config.ClientConnectionStrategyConfig.ReconnectMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.client.impl.ClientEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.client.impl.protocol.AuthenticationStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cluster.ClusterState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cluster.MemberAttributeOperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.AbstractXmlConfigBuilder.ConfigType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.CacheDeserializedValues
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.ConsistencyCheckStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.EvictionConfig.MaxSizePolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.EvictionPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.HotRestartClusterDataRecoveryPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.IndexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.InMemoryFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.MapStoreConfig.InitialLoadMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.MaxSizeConfig.MaxSizePolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.MetadataPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.MultiMapConfig.ValueCollectionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.NativeMemoryConfig.MemoryAllocatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.NearCacheConfig.LocalUpdatePolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.OnJoinPermissionOperationName
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.PartitionGroupConfig.MemberGroupType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.PermissionConfig.PermissionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.properties.PropertyTypeConverter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.RestEndpointGroup
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.security.LdapRoleMappingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.security.LdapSearchScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.security.TokenEncoding
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.UserCodeDeploymentConfig.ClassCacheMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.UserCodeDeploymentConfig.ProviderMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.WanAcknowledgeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.WanPublisherState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.config.WanQueueFullBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.core.DistributedObjectEvent.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.core.EntryEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.core.ItemEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.core.LifecycleEvent.LifecycleState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cp.CPGroup.CPGroupStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cp.internal.datastructures.atomiclong.operation.AlterOp.AlterResultType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cp.internal.datastructures.atomicref.operation.ApplyOp.ReturnValueType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cp.internal.datastructures.lock.AcquireResult.AcquireStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cp.internal.datastructures.semaphore.AcquireResult.AcquireStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cp.internal.raft.impl.RaftNodeStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cp.internal.raft.impl.RaftRole
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cp.internal.raft.MembershipChangeMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cp.internal.raft.QueryPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.cp.session.CPSession.CPSessionOwnerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.hotrestart.BackupTaskState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.instance.impl.NodeState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.instance.ProtocolType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.hazelcast.instance.ProtocolType
 
valueOf(String) - Static method in enum com.hazelcast.internal.adapter.DataStructureAdapter.DataStructureMethods
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.ascii.rest.HttpPostCommandProcessor.ResponseType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.ascii.TextCommandConstants.TextCommandType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.auditlog.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.cluster.fd.ClusterFailureDetectorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.cluster.impl.SplitBrainJoinMessage.SplitBrainMergeCheckResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.diagnostics.HealthMonitorLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.dynamicconfig.ConfigCheckMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.eviction.ClearExpiredRecordsTask.ProcessablePartitionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.eviction.CompositeEvictionChecker.CompositionOperator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.eviction.EvictionStrategyType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in class com.hazelcast.internal.json.JsonValue
Deprecated.
Use Json.value() instead
valueOf(long) - Static method in class com.hazelcast.internal.json.JsonValue
Deprecated.
Use Json.value() instead
valueOf(float) - Static method in class com.hazelcast.internal.json.JsonValue
Deprecated.
Use Json.value() instead
valueOf(double) - Static method in class com.hazelcast.internal.json.JsonValue
Deprecated.
Use Json.value() instead
valueOf(String) - Static method in class com.hazelcast.internal.json.JsonValue
Deprecated.
Use Json.value() instead
valueOf(boolean) - Static method in class com.hazelcast.internal.json.JsonValue
Deprecated.
Use Json.value() instead
valueOf(String) - Static method in enum com.hazelcast.internal.management.dto.ClientBwListDTO.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.management.dto.ClientBwListEntryDTO.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.management.dto.ClusterHotRestartStatusDTO.ClusterHotRestartStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.management.dto.ClusterHotRestartStatusDTO.MemberHotRestartStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.management.events.EventMetadata.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.memory.GlobalMemoryAccessorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.metrics.MetricTarget
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.metrics.ProbeLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.metrics.ProbeUnit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.networking.HandlerStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.networking.nio.NioOutboundPipeline.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.networking.nio.SelectorMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.nio.ConnectionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.nio.Packet.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.partition.impl.MigrationInterceptor.MigrationParticipant
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.partition.impl.PartitionServiceState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.partition.MigrationInfo.MigrationStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.serialization.DataType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.serialization.SerializableByConvention.Reason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.util.ConcurrentReferenceHashMap.Option
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.util.ConcurrentReferenceHashMap.ReferenceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.util.executor.ExecutorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.util.IterationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.util.JavaVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.internal.util.JavaVm
Returns the enum constant of this type with the specified name.
valueOf(long) - Static method in class com.hazelcast.internal.util.MutableLong
 
valueOf(String) - Static method in enum com.hazelcast.internal.util.scheduler.ScheduleType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.memory.MemoryUnit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.multimap.impl.operations.MultiMapOperationFactory.OperationFactoryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.nio.serialization.FieldType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.query.impl.AttributeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.query.impl.Comparison
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.query.impl.Index.OperationSource
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.query.impl.IndexCopyBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.query.impl.predicates.QueryOptimizerFactory.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.query.impl.QueryContext.IndexMatchHint
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.query.QueryConstants
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.ringbuffer.OverflowPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.scheduledexecutor.impl.TaskDefinition.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.spi.discovery.integration.DiscoveryMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.spi.impl.operationservice.ExceptionAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.spi.partition.MigrationEndpoint
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.splitbrainprotection.SplitBrainProtectionOn
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.topic.TopicOverloadPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.transaction.impl.Transaction.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.wan.impl.CallerProvenance
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.hazelcast.wan.impl.WanSyncStatus
Returns the enum constant of this type with the specified name.
ValueReader - Interface in com.hazelcast.query.extractor
Enables reading the value of the attribute specified by the path
ValueReadingException - Exception in com.hazelcast.query.extractor
Exception thrown if there is any checked or unchecked exception caught in the value reading in ValueReader
ValueReadingException(String, Throwable) - Constructor for exception com.hazelcast.query.extractor.ValueReadingException
 
values() - Static method in enum com.hazelcast.cache.CacheEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cache.impl.CacheEntryProcessorEntry.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cache.impl.CacheEntryViews.CacheEntryViewType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.client.ClientType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.client.config.ClientConnectionStrategyConfig.ReconnectMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.client.impl.ClientEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.client.impl.protocol.AuthenticationStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class com.hazelcast.client.impl.protocol.codec.ListCompareAndRemoveAllCodec.RequestParameters
The list of values to compare for removal.
values - Variable in class com.hazelcast.client.impl.protocol.codec.ListCompareAndRetainAllCodec.RequestParameters
The list of values to compare for retaining.
values - Variable in class com.hazelcast.client.impl.protocol.codec.ListContainsAllCodec.RequestParameters
Collection to be checked for containment in this list
values - Variable in class com.hazelcast.client.impl.protocol.codec.SetCompareAndRemoveAllCodec.RequestParameters
The list of values to test for matching the item to remove.
values - Variable in class com.hazelcast.client.impl.protocol.codec.SetCompareAndRetainAllCodec.RequestParameters
The list of values to test for matching the item to retain.
values() - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
values(Predicate) - Method in class com.hazelcast.client.impl.proxy.ClientMapProxy
 
values() - Method in class com.hazelcast.client.impl.proxy.ClientMultiMapProxy
 
values() - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
values(Comparator<V>) - Method in class com.hazelcast.client.impl.proxy.ClientReplicatedMapProxy
 
values() - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
values(Predicate) - Method in class com.hazelcast.client.impl.proxy.txn.ClientTxnMapProxy
 
values() - Static method in enum com.hazelcast.cluster.ClusterState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cluster.MemberAttributeOperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.AbstractXmlConfigBuilder.ConfigType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.CacheDeserializedValues
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.ConsistencyCheckStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.EvictionConfig.MaxSizePolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.EvictionPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.HotRestartClusterDataRecoveryPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.IndexType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.InMemoryFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.MapStoreConfig.InitialLoadMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.MaxSizeConfig.MaxSizePolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.MetadataPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.MultiMapConfig.ValueCollectionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.NativeMemoryConfig.MemoryAllocatorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.NearCacheConfig.LocalUpdatePolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.OnJoinPermissionOperationName
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.PartitionGroupConfig.MemberGroupType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.PermissionConfig.PermissionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.properties.PropertyTypeConverter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.RestEndpointGroup
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.security.LdapRoleMappingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.security.LdapSearchScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.security.TokenEncoding
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.UserCodeDeploymentConfig.ClassCacheMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.UserCodeDeploymentConfig.ProviderMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.WanAcknowledgeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.WanPublisherState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.config.WanQueueFullBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.core.DistributedObjectEvent.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.core.EntryEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.core.ItemEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.core.LifecycleEvent.LifecycleState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cp.CPGroup.CPGroupStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cp.internal.datastructures.atomiclong.operation.AlterOp.AlterResultType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cp.internal.datastructures.atomicref.operation.ApplyOp.ReturnValueType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cp.internal.datastructures.lock.AcquireResult.AcquireStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cp.internal.datastructures.semaphore.AcquireResult.AcquireStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueSnapshot
 
values() - Static method in enum com.hazelcast.cp.internal.raft.impl.RaftNodeStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cp.internal.raft.impl.RaftRole
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cp.internal.raft.MembershipChangeMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cp.internal.raft.QueryPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.cp.session.CPSession.CPSessionOwnerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.hotrestart.BackupTaskState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.instance.impl.NodeState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.instance.ProtocolType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.adapter.DataStructureAdapter.DataStructureMethods
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.ascii.rest.HttpPostCommandProcessor.ResponseType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.ascii.TextCommandConstants.TextCommandType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.auditlog.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.cluster.fd.ClusterFailureDetectorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.cluster.impl.SplitBrainJoinMessage.SplitBrainMergeCheckResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.diagnostics.HealthMonitorLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.hazelcast.internal.dynamicconfig.AggregatingMap
 
values() - Static method in enum com.hazelcast.internal.dynamicconfig.ConfigCheckMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.eviction.ClearExpiredRecordsTask.ProcessablePartitionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.eviction.CompositeEvictionChecker.CompositionOperator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.eviction.EvictionStrategyType
Returns an array containing the constants of this enum type, in the order they are declared.
values(String) - Method in class com.hazelcast.internal.jmx.MapMBean
 
values() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
 
values() - Method in class com.hazelcast.internal.json.JsonArray
Returns a list of the values in this array in document order.
values() - Static method in enum com.hazelcast.internal.management.dto.ClientBwListDTO.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.management.dto.ClientBwListEntryDTO.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.management.dto.ClusterHotRestartStatusDTO.ClusterHotRestartStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.management.dto.ClusterHotRestartStatusDTO.MemberHotRestartStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.management.events.EventMetadata.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.memory.GlobalMemoryAccessorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.metrics.MetricTarget
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.metrics.ProbeLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.metrics.ProbeUnit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.networking.HandlerStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.networking.nio.NioOutboundPipeline.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.networking.nio.SelectorMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.nio.ConnectionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.nio.Packet.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.partition.impl.MigrationInterceptor.MigrationParticipant
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.partition.impl.PartitionServiceState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.partition.MigrationInfo.MigrationStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.serialization.DataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.serialization.SerializableByConvention.Reason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.hazelcast.internal.util.collection.Int2ObjectHashMap
 
values() - Method in class com.hazelcast.internal.util.collection.Long2LongHashMap
 
values() - Method in class com.hazelcast.internal.util.collection.Long2ObjectHashMap
 
values() - Static method in enum com.hazelcast.internal.util.ConcurrentReferenceHashMap.Option
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.util.ConcurrentReferenceHashMap.ReferenceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.hazelcast.internal.util.ConcurrentReferenceHashMap
Returns a Collection view of the values contained in this map.
values() - Static method in enum com.hazelcast.internal.util.executor.ExecutorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.util.IterationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.util.JavaVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.util.JavaVm
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.internal.util.scheduler.ScheduleType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface com.hazelcast.map.BaseMap
Returns a collection clone of the values contained in this map.
values(Predicate<K, V>) - Method in interface com.hazelcast.map.BaseMap
Queries the map based on the specified predicate and returns the values of matching entries.
values() - Method in interface com.hazelcast.map.IMap
Returns an immutable collection clone of the values contained in this map.
values(Predicate<K, V>) - Method in interface com.hazelcast.map.IMap
Queries the map based on the specified predicate and returns an immutable collection of the values of matching entries.
VALUES - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
values() - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
values(Predicate) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
values() - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
values(Predicate) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
values() - Method in interface com.hazelcast.map.impl.recordstore.Storage
 
values() - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
 
values() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
values(Predicate) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
values() - Method in interface com.hazelcast.map.QueryCache
 
values(Predicate<K, V>) - Method in interface com.hazelcast.map.QueryCache
 
values() - Static method in enum com.hazelcast.memory.MemoryUnit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
VALUES - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
values() - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
values() - Static method in enum com.hazelcast.multimap.impl.operations.MultiMapOperationFactory.OperationFactoryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface com.hazelcast.multimap.MultiMap
Returns the collection of values in the multimap.
values() - Static method in enum com.hazelcast.nio.serialization.FieldType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.query.impl.AttributeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.query.impl.Comparison
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.query.impl.Index.OperationSource
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.query.impl.IndexCopyBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.query.impl.predicates.QueryOptimizerFactory.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.query.impl.QueryContext.IndexMatchHint
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.query.QueryConstants
Returns an array containing the constants of this enum type, in the order they are declared.
VALUES - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
values(boolean) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
values(Comparator) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
values() - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
 
values(boolean) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
values(Comparator) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
values() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
values(Comparator<V>) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
values() - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Returns a lazy Collection view of the values contained in this map.
A LazyCollection is optimized for querying speed (preventing eager deserialization and hashing on HashSet insertion) and does NOT provide all operations.
values(Comparator<V>) - Method in interface com.hazelcast.replicatedmap.ReplicatedMap
Returns an eagerly populated Collection view of the values contained in this map.
values() - Static method in enum com.hazelcast.ringbuffer.OverflowPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.scheduledexecutor.impl.TaskDefinition.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.spi.discovery.integration.DiscoveryMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.spi.impl.operationservice.ExceptionAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.spi.partition.MigrationEndpoint
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.spi.partitiongroup.PartitionGroupMetaData
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.splitbrainprotection.SplitBrainProtectionOn
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.topic.TopicOverloadPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.transaction.impl.Transaction.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.values().
values(Predicate<K, V>) - Method in interface com.hazelcast.transaction.TransactionalMap
Transactional implementation of IMap.values(com.hazelcast.query.Predicate).
values() - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.wan.impl.CallerProvenance
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.hazelcast.wan.impl.WanSyncStatus
Returns an array containing the constants of this enum type, in the order they are declared.
VALUES_COLLECTION - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
 
valuesAsSet() - Static method in enum com.hazelcast.instance.ProtocolType
 
valuesInternal() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
ValuesOperation - Class in com.hazelcast.multimap.impl.operations
 
ValuesOperation() - Constructor for class com.hazelcast.multimap.impl.operations.ValuesOperation
 
ValuesOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.ValuesOperation
 
ValuesOperation - Class in com.hazelcast.replicatedmap.impl.operation
 
ValuesOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ValuesOperation
 
ValuesOperation(String) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ValuesOperation
 
valueToData(Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
valueToData(Object) - Method in class com.hazelcast.cache.impl.CacheRecordStore
 
valueType - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
class name of value type
ValueValidator<T extends Comparable<T>> - Interface in com.hazelcast.config.properties
This interface defines a certain validation logic implementation to test if a given value is expected to be correct or not.
VaultSecureStoreConfig - Class in com.hazelcast.config
HashiCorp Vault Secure Store configuration.
VaultSecureStoreConfig(String, String, String) - Constructor for class com.hazelcast.config.VaultSecureStoreConfig
Creates a new Vault Secure Store configuration.
VECTOR_CLOCK - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
VectorClock - Class in com.hazelcast.cluster.impl
Vector clock consisting of distinct replica logical clocks.
VectorClock() - Constructor for class com.hazelcast.cluster.impl.VectorClock
 
VectorClock(VectorClock) - Constructor for class com.hazelcast.cluster.impl.VectorClock
 
verify() - Method in class com.hazelcast.config.JoinConfig
Verifies this JoinConfig is valid.
verifyProtocol(String) - Method in class com.hazelcast.internal.nio.tcp.SingleProtocolDecoder
 
verifyProtocol(String) - Method in class com.hazelcast.internal.nio.tcp.TextHandshakeDecoder
 
verifyRestartedMember(long, CPMemberInfo) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupManager
 
verifySplitBrainMergeMemberListVersion(SplitBrainJoinMessage) - Method in class com.hazelcast.internal.cluster.impl.MembershipManager
 
version - Variable in class com.hazelcast.cluster.impl.AbstractMember
 
version(MemberVersion) - Method in class com.hazelcast.cluster.impl.MemberImpl.Builder
 
version() - Method in class com.hazelcast.cp.internal.session.CPSessionInfo
 
version() - Method in interface com.hazelcast.cp.session.CPSession
Returns version of the session.
VERSION - Static variable in class com.hazelcast.instance.GeneratedBuildProperties
 
VERSION - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
VERSION - Static variable in class com.hazelcast.internal.nio.Packet
 
version - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
version - Variable in class com.hazelcast.map.impl.record.AbstractRecord
 
version - Variable in class com.hazelcast.map.impl.record.RecordInfo
 
Version - Class in com.hazelcast.version
A generic version to be used with VersionAware classes.
Version() - Constructor for class com.hazelcast.version.Version
 
VERSION_1 - Static variable in interface com.hazelcast.internal.serialization.InternalSerializationService
 
VERSION_PATTERN - Static variable in class com.hazelcast.internal.util.StringUtil
Pattern used to tokenize version strings.
VERSION_RESPONSE_PAIR - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
 
VersionAware - Interface in com.hazelcast.nio
An instance which supports versioning.
VersionAwareConstructorFunction<K,V> - Interface in com.hazelcast.internal.util
VersionAware version of the ConstructorFunction.
VersionCommand - Class in com.hazelcast.internal.ascii.memcache
 
VersionCommand(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.internal.ascii.memcache.VersionCommand
 
VersionCommandProcessor - Class in com.hazelcast.internal.ascii.memcache
 
VersionCommandProcessor(TextCommandServiceImpl) - Constructor for class com.hazelcast.internal.ascii.memcache.VersionCommandProcessor
 
Versioned - Interface in com.hazelcast.nio.serialization.impl
Marker interface that enables marking a DataSerializable or IdentifiedDataSerializable class for versioning.
VERSIONED_VALUE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
VersionedDataSerializableFactory - Interface in com.hazelcast.nio.serialization.impl
VersionedDataSerializableFactory is used to create IdentifiedDataSerializable instances during de-serialization.
VersionedPortable - Interface in com.hazelcast.nio.serialization
VersionedPortable is an extension to Portable to support per class version instead of a global serialization version.
VersionedValue - Class in com.hazelcast.map.impl.tx
Wrapper for Data value objects with version information.
VersionedValue(Data, long) - Constructor for class com.hazelcast.map.impl.tx.VersionedValue
 
VersionedValue() - Constructor for class com.hazelcast.map.impl.tx.VersionedValue
 
VersionMismatchException - Exception in com.hazelcast.internal.cluster.impl
Indicates that the version of a joining member is not compatible with the cluster version.
VersionMismatchException(String) - Constructor for exception com.hazelcast.internal.cluster.impl.VersionMismatchException
 
VersionResponsePair - Class in com.hazelcast.replicatedmap.impl.operation
Contains response and partition version for update operations on replicated map.
VersionResponsePair() - Constructor for class com.hazelcast.replicatedmap.impl.operation.VersionResponsePair
 
VersionResponsePair(Object, long) - Constructor for class com.hazelcast.replicatedmap.impl.operation.VersionResponsePair
 
Versions - Class in com.hazelcast.internal.cluster
 
visit(AndPredicate, Indexes) - Method in class com.hazelcast.query.impl.predicates.AbstractVisitor
 
visit(OrPredicate, Indexes) - Method in class com.hazelcast.query.impl.predicates.AbstractVisitor
 
visit(NotPredicate, Indexes) - Method in class com.hazelcast.query.impl.predicates.AbstractVisitor
 
visit(BetweenPredicate, Indexes) - Method in class com.hazelcast.query.impl.predicates.AbstractVisitor
 
visit(AndPredicate, Indexes) - Method in class com.hazelcast.query.impl.predicates.CompositeIndexVisitor
 
visit(AndPredicate, Indexes) - Method in class com.hazelcast.query.impl.predicates.FlatteningVisitor
 
visit(OrPredicate, Indexes) - Method in class com.hazelcast.query.impl.predicates.FlatteningVisitor
 
visit(NotPredicate, Indexes) - Method in class com.hazelcast.query.impl.predicates.FlatteningVisitor
 
visit(OrPredicate, Indexes) - Method in class com.hazelcast.query.impl.predicates.OrToInVisitor
 
visit(AndPredicate, Indexes) - Method in class com.hazelcast.query.impl.predicates.RangeVisitor
 
visit(BetweenPredicate, Indexes) - Method in class com.hazelcast.query.impl.predicates.RangeVisitor
 
visit(AndPredicate, Indexes) - Method in interface com.hazelcast.query.impl.predicates.Visitor
 
visit(OrPredicate, Indexes) - Method in interface com.hazelcast.query.impl.predicates.Visitor
 
visit(NotPredicate, Indexes) - Method in interface com.hazelcast.query.impl.predicates.Visitor
 
visit(BetweenPredicate, Indexes) - Method in interface com.hazelcast.query.impl.predicates.Visitor
 
VisitablePredicate - Interface in com.hazelcast.query.impl.predicates
Predicates which can be visited by optimizer.
Visitor - Interface in com.hazelcast.query.impl.predicates
Visitor can inspect internal state of a node, but it's not allowed to mutate its internal state.
VisitorUtils - Class in com.hazelcast.query.impl.predicates
 
VOTE_REQUEST - Static variable in class com.hazelcast.cp.internal.raft.impl.RaftDataSerializerHook
 
VOTE_REQUEST_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
VOTE_RESPONSE - Static variable in class com.hazelcast.cp.internal.raft.impl.RaftDataSerializerHook
 
VOTE_RESPONSE_OP - Static variable in class com.hazelcast.cp.internal.RaftServiceDataSerializerHook
 
voteCount() - Method in class com.hazelcast.cp.internal.raft.impl.state.CandidateState
Returns current granted number of the votes.
votedFor() - Method in class com.hazelcast.cp.internal.raft.impl.persistence.RestoredRaftState
 
votedFor() - Method in class com.hazelcast.cp.internal.raft.impl.state.RaftState
Returns the endpoint this note voted for
voteFor(WeightedEvictableList.WeightedItem<T>) - Method in class com.hazelcast.internal.util.collection.WeightedEvictableList
Casts a vote for given list node.
voteFor(WeightedEvictableList.WeightedItem<JsonPattern>) - Method in class com.hazelcast.query.impl.getters.JsonGetterContext
 
voter() - Method in class com.hazelcast.cp.internal.raft.impl.dto.PreVoteResponse
 
voter() - Method in class com.hazelcast.cp.internal.raft.impl.dto.VoteResponse
 
VoteRequest - Class in com.hazelcast.cp.internal.raft.impl.dto
Struct for VoteRequest RPC.
VoteRequest() - Constructor for class com.hazelcast.cp.internal.raft.impl.dto.VoteRequest
 
VoteRequest(RaftEndpoint, int, int, long, boolean) - Constructor for class com.hazelcast.cp.internal.raft.impl.dto.VoteRequest
 
VoteRequestHandlerTask - Class in com.hazelcast.cp.internal.raft.impl.handler
Handles VoteRequest sent by a candidate.
VoteRequestHandlerTask(RaftNodeImpl, VoteRequest) - Constructor for class com.hazelcast.cp.internal.raft.impl.handler.VoteRequestHandlerTask
 
VoteRequestOp - Class in com.hazelcast.cp.internal.operation.integration
Carries a VoteRequest RPC from a Raft candidate to a follower
VoteRequestOp() - Constructor for class com.hazelcast.cp.internal.operation.integration.VoteRequestOp
 
VoteRequestOp(CPGroupId, VoteRequest) - Constructor for class com.hazelcast.cp.internal.operation.integration.VoteRequestOp
 
VoteResponse - Class in com.hazelcast.cp.internal.raft.impl.dto
Struct for response to VoteRequest RPC.
VoteResponse() - Constructor for class com.hazelcast.cp.internal.raft.impl.dto.VoteResponse
 
VoteResponse(RaftEndpoint, int, boolean) - Constructor for class com.hazelcast.cp.internal.raft.impl.dto.VoteResponse
 
VoteResponseHandlerTask - Class in com.hazelcast.cp.internal.raft.impl.handler
VoteResponseHandlerTask(RaftNodeImpl, VoteResponse) - Constructor for class com.hazelcast.cp.internal.raft.impl.handler.VoteResponseHandlerTask
 
VoteResponseOp - Class in com.hazelcast.cp.internal.operation.integration
Carries a VoteResponse from a Raft follower to a candidate
VoteResponseOp() - Constructor for class com.hazelcast.cp.internal.operation.integration.VoteResponseOp
 
VoteResponseOp(CPGroupId, VoteResponse) - Constructor for class com.hazelcast.cp.internal.operation.integration.VoteResponseOp
 

W

W3cDomUtil - Class in com.hazelcast.internal.config.yaml
Utility methods for YAML to W3C adaptors
WAIT - Static variable in class com.hazelcast.spi.impl.operationservice.CallStatus
Indicates that the call could not complete because waiting is required.
WAIT_KEY_CANCELLED_EXCEPTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
WAIT_KEY_CONTAINER - Static variable in class com.hazelcast.cp.internal.datastructures.RaftDataServiceDataSerializerHook
 
WAIT_ORDINAL - Static variable in class com.hazelcast.spi.impl.operationservice.CallStatus
The ordinal value for a CallStatus.WAIT.
WAIT_SECONDS_BEFORE_JOIN - Static variable in class com.hazelcast.spi.properties.GroupProperty
 
WAIT_TIMEOUT_TASK_UPPER_BOUND_MILLIS - Static variable in class com.hazelcast.cp.internal.datastructures.spi.blocking.AbstractBlockingService
 
waitCompletionLatch(Integer, InternalCompletableFuture) - Method in class com.hazelcast.cache.impl.AbstractCacheSyncListenerCompleter
 
waitCompletionLatch(Integer) - Method in class com.hazelcast.cache.impl.AbstractCacheSyncListenerCompleter
 
waitCompletionLatch(Integer, int) - Method in class com.hazelcast.cache.impl.AbstractCacheSyncListenerCompleter
 
waitForever(Collection<? extends Future>, FutureUtil.ExceptionHandler) - Static method in class com.hazelcast.internal.util.FutureUtil
 
waitForever(Collection<? extends Future>) - Static method in class com.hazelcast.internal.util.FutureUtil
 
WaitKey - Class in com.hazelcast.cp.internal.datastructures.spi.blocking
This abstraction is used when an operation does not return a response at commit-time.
WaitKey() - Constructor for class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKey
 
WaitKey(long, UUID, Address, long) - Constructor for class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKey
 
WaitKeyCancelledException - Exception in com.hazelcast.cp.internal.datastructures.exception
Thrown when a wait key is cancelled and means that the corresponding operation has not succeeded
WaitKeyCancelledException() - Constructor for exception com.hazelcast.cp.internal.datastructures.exception.WaitKeyCancelledException
 
WaitKeyCancelledException(String) - Constructor for exception com.hazelcast.cp.internal.datastructures.exception.WaitKeyCancelledException
 
WaitKeyCancelledException(String, Throwable) - Constructor for exception com.hazelcast.cp.internal.datastructures.exception.WaitKeyCancelledException
 
WaitKeyContainer<W extends WaitKey> - Class in com.hazelcast.cp.internal.datastructures.spi.blocking
Contains all wait keys for an invocation uid within the same session, including the first invocation and its retries
WaitKeyContainer() - Constructor for class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKeyContainer
 
waitKeyContainersIterator() - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.BlockingResource
 
WaitNotifyKey - Interface in com.hazelcast.spi.impl.operationservice
A key for a wait notify object.
waitPartitionReplicaSyncOnCluster(long, TimeUnit) - Method in interface com.hazelcast.internal.hotrestart.InternalHotRestartService
Waits until partition replicas (primaries and backups) get in sync.
waitPartitionReplicaSyncOnCluster(long, TimeUnit) - Method in class com.hazelcast.internal.hotrestart.NoopInternalHotRestartService
 
WaitSet - Class in com.hazelcast.spi.impl.operationparker.impl
The WaitSet is a effectively a set of operations waiting for some condition.
WaitSet(ILogger, NodeEngine, Map<WaitNotifyKey, WaitSet>, Queue<WaitSetEntry>) - Constructor for class com.hazelcast.spi.impl.operationparker.impl.WaitSet
 
waitTimeMillis - Variable in class com.hazelcast.flakeidgen.impl.FlakeIdGeneratorProxy.IdBatchAndWaitTime
 
waitTimeouts - Variable in class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
waitUntilAllResponded(Collection<? extends Future>) - Static method in class com.hazelcast.internal.util.FutureUtil
 
waitUntilAllRespondedWithDeadline(Collection<? extends Future>, long, TimeUnit, FutureUtil.ExceptionHandler) - Static method in class com.hazelcast.internal.util.FutureUtil
 
waitUntilLoaded() - Method in class com.hazelcast.internal.adapter.IMapDataStructureAdapter
 
waitWithDeadline(Collection<? extends Future>, long, TimeUnit) - Static method in class com.hazelcast.internal.util.FutureUtil
 
waitWithDeadline(Collection<? extends Future>, long, TimeUnit, FutureUtil.ExceptionHandler) - Static method in class com.hazelcast.internal.util.FutureUtil
 
waitWithDeadline(Collection<? extends Future>, long, TimeUnit, long, TimeUnit) - Static method in class com.hazelcast.internal.util.FutureUtil
 
waitWithDeadline(Collection<? extends Future>, long, TimeUnit, long, TimeUnit, FutureUtil.ExceptionHandler) - Static method in class com.hazelcast.internal.util.FutureUtil
 
wakeup() - Method in interface com.hazelcast.internal.networking.InboundPipeline
Wakes up the inbound pipeline and lets it to start reading again from the network.
wakeup() - Method in class com.hazelcast.internal.networking.nio.NioInboundPipeline
 
wakeup() - Method in class com.hazelcast.internal.networking.nio.NioOutboundPipeline
 
wakeup() - Method in interface com.hazelcast.internal.networking.OutboundPipeline
Request to flush all data to flush from the handlers to the network.
WAN_BATCH_PUBLISHER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
WAN_CONSUMER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
WAN_CUSTOM_PUBLISHER_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
WAN_MAP_ENTRY_VIEW - Static variable in class com.hazelcast.wan.impl.WanDataSerializerHook
 
WAN_REPLICATION_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
WAN_REPLICATION_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
WAN_REPLICATION_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
WAN_REPLICATION_QUEUE_FULL - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
WAN_SYNC_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
WanAcknowledgeType - Enum in com.hazelcast.config
Determines acknowledge waiting type of wan replication operation invocation.
WanAntiEntropyEvent - Interface in com.hazelcast.wan
A user-triggered WAN anti-entropy event.
WanBatchReplicationPublisherConfig - Class in com.hazelcast.config
Configuration object for the built-in WAN publisher (available in Hazelcast Enterprise).
WanBatchReplicationPublisherConfig() - Constructor for class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
WanBatchReplicationPublisherConfigDTO - Class in com.hazelcast.internal.management.dto
A JSON representation of WanBatchReplicationPublisherConfig.
WanBatchReplicationPublisherConfigDTO() - Constructor for class com.hazelcast.internal.management.dto.WanBatchReplicationPublisherConfigDTO
 
WanBatchReplicationPublisherConfigDTO(WanBatchReplicationPublisherConfig) - Constructor for class com.hazelcast.internal.management.dto.WanBatchReplicationPublisherConfigDTO
 
WanCheckConsistencyOperation - Class in com.hazelcast.internal.management.operation
Checking consistency of the given map for the given wan replication schema and publisher
WanCheckConsistencyOperation(String, String, String) - Constructor for class com.hazelcast.internal.management.operation.WanCheckConsistencyOperation
 
WanCheckConsistencyRequest - Class in com.hazelcast.internal.management.request
 
WanCheckConsistencyRequest() - Constructor for class com.hazelcast.internal.management.request.WanCheckConsistencyRequest
 
WanCheckConsistencyRequest(String, String, String) - Constructor for class com.hazelcast.internal.management.request.WanCheckConsistencyRequest
 
WanConfigurationAddedEvent - Class in com.hazelcast.internal.management.events
 
WanConfigurationAddedEvent(String) - Constructor for class com.hazelcast.internal.management.events.WanConfigurationAddedEvent
 
WanConfigurationExtendedEvent - Class in com.hazelcast.internal.management.events
 
WanConfigurationExtendedEvent(String, Collection<String>) - Constructor for class com.hazelcast.internal.management.events.WanConfigurationExtendedEvent
 
WanConsistencyCheckFinishedEvent - Class in com.hazelcast.internal.management.events
 
WanConsistencyCheckFinishedEvent(UUID, String, String, String, int, int, int) - Constructor for class com.hazelcast.internal.management.events.WanConsistencyCheckFinishedEvent
 
WanConsistencyCheckIgnoredEvent - Class in com.hazelcast.internal.management.events
 
WanConsistencyCheckIgnoredEvent(String, String, String, String) - Constructor for class com.hazelcast.internal.management.events.WanConsistencyCheckIgnoredEvent
 
WanConsistencyCheckStartedEvent - Class in com.hazelcast.internal.management.events
 
WanConsistencyCheckStartedEvent(UUID, String, String, String) - Constructor for class com.hazelcast.internal.management.events.WanConsistencyCheckStartedEvent
 
WanConsumerConfig - Class in com.hazelcast.config
Config for processing WAN events received from a target cluster.
WanConsumerConfig() - Constructor for class com.hazelcast.config.WanConsumerConfig
 
WanConsumerConfigDTO - Class in com.hazelcast.internal.management.dto
A JSON representation of WanConsumerConfig.
WanConsumerConfigDTO() - Constructor for class com.hazelcast.internal.management.dto.WanConsumerConfigDTO
 
WanConsumerConfigDTO(WanConsumerConfig) - Constructor for class com.hazelcast.internal.management.dto.WanConsumerConfigDTO
 
WanDataSerializerHook - Class in com.hazelcast.wan.impl
DataSerializerHook implementation for Wan Replication classes
WanDataSerializerHook() - Constructor for class com.hazelcast.wan.impl.WanDataSerializerHook
 
WanEventCounters - Class in com.hazelcast.wan.impl
Thread safe container for DistributedServiceWanEventCounters grouped by WAN publisher, distributed service name and distributed object name.
WanEventCounters() - Constructor for class com.hazelcast.wan.impl.WanEventCounters
 
WanEventHolder - Class in com.hazelcast.map.impl.operation
 
WanEventHolder(Data, Data, EntryEventType) - Constructor for class com.hazelcast.map.impl.operation.WanEventHolder
 
wanEventPublisher - Variable in class com.hazelcast.cache.impl.operation.CacheOperation
 
WanFullSyncFinishedEvent - Class in com.hazelcast.internal.management.events
 
WanFullSyncFinishedEvent(UUID, String, String, String, long, long, int) - Constructor for class com.hazelcast.internal.management.events.WanFullSyncFinishedEvent
 
WanMapEntryView<K,V> - Class in com.hazelcast.map.impl.wan
WAN heap based implementation of EntryView.
WanMapEntryView() - Constructor for class com.hazelcast.map.impl.wan.WanMapEntryView
 
WanMapEntryView(EntryView<K, V>) - Constructor for class com.hazelcast.map.impl.wan.WanMapEntryView
 
wanMergePolicy - Variable in class com.hazelcast.map.impl.MapContainer
 
WanMerkleSyncFinishedEvent - Class in com.hazelcast.internal.management.events
 
WanMerkleSyncFinishedEvent(UUID, String, String, String, long, int, int, long, int, int, double, double) - Constructor for class com.hazelcast.internal.management.events.WanMerkleSyncFinishedEvent
 
WanProtocolVersionAware - Interface in com.hazelcast.nio
An instance which is used in WAN and supports versioning.
WanPublisherMBean - Class in com.hazelcast.internal.jmx
Management bean for a single WAN replication publisher.
WanPublisherMBean(WanReplicationService, String, String, ManagementService) - Constructor for class com.hazelcast.internal.jmx.WanPublisherMBean
 
WanPublisherState - Enum in com.hazelcast.config
Defines the state in which a WAN publisher can be in if it is not shutting down.
WanQueueFullBehavior - Enum in com.hazelcast.config
Determines the behavior of WAN replication impl.
WanReplicationConfig - Class in com.hazelcast.config
Configuration for WAN replication.
WanReplicationConfig() - Constructor for class com.hazelcast.config.WanReplicationConfig
 
WanReplicationConfigDTO - Class in com.hazelcast.internal.management.dto
A JSON representation of WanReplicationConfig.
WanReplicationConfigDTO(WanReplicationConfig) - Constructor for class com.hazelcast.internal.management.dto.WanReplicationConfigDTO
 
wanReplicationDelegate - Variable in class com.hazelcast.map.impl.MapContainer
 
wanReplicationEnabled - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
WanReplicationEvent - Interface in com.hazelcast.wan
Interface for all WAN replication messages
WanReplicationOperation - Interface in com.hazelcast.internal.cluster.impl.operations
Marker interface for WAN Replication Operations
WanReplicationPublisher<T> - Interface in com.hazelcast.wan
This interface offers the implementation of different kinds of replication techniques like TCP, UDP or maybe even an JMS based service.
WanReplicationQueueFullException - Exception in com.hazelcast.wan
A HazelcastException that is thrown when the wan replication queues are full This exception is only thrown when WAN is configured with WanQueueFullBehavior.THROW_EXCEPTION
WanReplicationQueueFullException(String) - Constructor for exception com.hazelcast.wan.WanReplicationQueueFullException
 
wanReplicationRef - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
reference to an existing WAN replication configuration
wanReplicationRef - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddMapConfigCodec.RequestParameters
reference to an existing WAN replication configuration
WanReplicationRef - Class in com.hazelcast.config
Configuration for a WAN target replication reference.
WanReplicationRef() - Constructor for class com.hazelcast.config.WanReplicationRef
 
WanReplicationRef(WanReplicationRef) - Constructor for class com.hazelcast.config.WanReplicationRef
 
WanReplicationRef(String, String, List<String>, boolean) - Constructor for class com.hazelcast.config.WanReplicationRef
 
WanReplicationRefCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
WanReplicationRefReadOnly - Class in com.hazelcast.internal.config
Configuration for Wan target replication reference(read only)
WanReplicationRefReadOnly(WanReplicationRef) - Constructor for class com.hazelcast.internal.config.WanReplicationRefReadOnly
 
WanReplicationService - Interface in com.hazelcast.wan.impl
This is the WAN replications service API core interface.
WanReplicationServiceImpl - Class in com.hazelcast.wan.impl
Open source implementation of the WanReplicationService
WanReplicationServiceImpl(Node) - Constructor for class com.hazelcast.wan.impl.WanReplicationServiceImpl
 
WanSyncConfig - Class in com.hazelcast.config
Configuration object for the WAN sync mechanism.
WanSyncConfig() - Constructor for class com.hazelcast.config.WanSyncConfig
 
WanSyncConfigDTO - Class in com.hazelcast.internal.management.dto
A JSON representation of WanSyncConfig.
WanSyncConfigDTO() - Constructor for class com.hazelcast.internal.management.dto.WanSyncConfigDTO
 
WanSyncConfigDTO(WanSyncConfig) - Constructor for class com.hazelcast.internal.management.dto.WanSyncConfigDTO
 
WanSyncIgnoredEvent - Class in com.hazelcast.internal.management.events
 
WanSyncProgressUpdateEvent - Class in com.hazelcast.internal.management.events
 
WanSyncProgressUpdateEvent(UUID, String, String, String, int, int, int) - Constructor for class com.hazelcast.internal.management.events.WanSyncProgressUpdateEvent
 
WanSyncStartedEvent - Class in com.hazelcast.internal.management.events
 
WanSyncStartedEvent(UUID, String, String, String) - Constructor for class com.hazelcast.internal.management.events.WanSyncStartedEvent
 
WanSyncState - Interface in com.hazelcast.monitor
Local WAN sync statistics to be used by MemberState implementations.
WanSyncStateImpl - Class in com.hazelcast.monitor.impl
 
WanSyncStateImpl() - Constructor for class com.hazelcast.monitor.impl.WanSyncStateImpl
 
WanSyncStateImpl(WanSyncStatus, int, String, String) - Constructor for class com.hazelcast.monitor.impl.WanSyncStateImpl
 
WanSyncStats - Interface in com.hazelcast.wan
Base interface of WAN Synchronization statistics.
WanSyncStatus - Enum in com.hazelcast.wan.impl
WanSyncStatus shows the current status of WAN sync.
warning(String) - Method in class com.hazelcast.logging.AbstractLogger
 
warning(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
warning(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
 
warning(String) - Method in interface com.hazelcast.logging.ILogger
Logs a message at the Level.WARNING level.
warning(Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a throwable at the Level.WARNING level.
warning(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
Logs a message with an associated throwable at the Level.WARNING level.
wbqCapacityCounter() - Method in class com.hazelcast.map.impl.operation.MapOperation
 
WEB_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
WeightedEvictableList<T> - Class in com.hazelcast.internal.util.collection
This list keeps the items as long as its size is less than maximum capacity.
WeightedEvictableList(int, int) - Constructor for class com.hazelcast.internal.util.collection.WeightedEvictableList
 
WeightedEvictableList.WeightedItem<T> - Class in com.hazelcast.internal.util.collection
A node that contains an item and its weight
whenComplete(BiConsumer<? super V, ? super Throwable>) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
whenComplete() - Method in class com.hazelcast.internal.metrics.jmx.JmxPublisher
 
whenComplete() - Method in class com.hazelcast.internal.metrics.managementcenter.ManagementCenterPublisher
 
whenComplete() - Method in interface com.hazelcast.internal.metrics.MetricsPublisher
Callback is called after all metrics are published for a given metric collection round.
whenComplete(BiConsumer<? super V, ? super Throwable>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
whenComplete(BiConsumer<? super V, ? super Throwable>) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
whenComplete(BiConsumer<? super V, ? super Throwable>) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
whenCompleteAsync(BiConsumer<? super V, ? super Throwable>) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
whenCompleteAsync(BiConsumer<? super V, ? super Throwable>, Executor) - Method in class com.hazelcast.client.impl.ClientDelegatingFuture
 
whenCompleteAsync(BiConsumer<? super ClientMessage, ? super Throwable>, Executor) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
whenCompleteAsync(BiConsumer<? super V, ? super Throwable>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
whenCompleteAsync(BiConsumer<? super V, ? super Throwable>, Executor) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
whenCompleteAsync(BiConsumer<? super V, ? super Throwable>) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
whenCompleteAsync(BiConsumer<? super V, ? super Throwable>, Executor) - Method in class com.hazelcast.spi.impl.DelegatingCompletableFuture
 
whenCompleteAsync(BiConsumer<? super V, ? super Throwable>) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
whenCompleteAsync(BiConsumer<? super V, ? super Throwable>, Executor) - Method in class com.hazelcast.spi.impl.DeserializingCompletableFuture
 
WHOIS_MASTER - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
WhoisMasterOp - Class in com.hazelcast.internal.cluster.impl.operations
 
WhoisMasterOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.WhoisMasterOp
 
WhoisMasterOp(JoinMessage) - Constructor for class com.hazelcast.internal.cluster.impl.operations.WhoisMasterOp
 
wholeItem() - Static method in class com.hazelcast.internal.util.function.Functions
Synonym for FunctionEx.identity(), to be used as a projection function (e.g., key extractor).
WildcardConfigPatternMatcher - Class in com.hazelcast.config.matcher
This ConfigPatternMatcher supports a simplified wildcard matching.
WildcardConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
 
withAcceptableHeartbeatPauseMillis(long) - Method in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
Duration in milliseconds corresponding to number of potentially lost/delayed heartbeats that will be accepted before considering it to be an anomaly.
withBufferPoolFactory(BufferPoolFactory) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService.Builder
 
withCacheName(String) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRequest
 
withClassLoader(ClassLoader) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService.Builder
 
withClassNameFilter(ClassNameFilter) - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1.AbstractBuilder
 
withContext(QueryCacheContext) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRequest
 
withCost(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
withCreationTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
withDataKey(Data) - Method in class com.hazelcast.map.impl.querycache.event.QueryCacheEventDataBuilder
 
withDataNewValue(Data) - Method in class com.hazelcast.map.impl.querycache.event.QueryCacheEventDataBuilder
 
withDataOldValue(Data) - Method in class com.hazelcast.map.impl.querycache.event.QueryCacheEventDataBuilder
 
withDataSerializableFactories(Map<Integer, ? extends DataSerializableFactory>) - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1.AbstractBuilder
 
withEnableCompression(boolean) - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1.AbstractBuilder
 
withEnableSharedObject(boolean) - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1.AbstractBuilder
 
withEventType(int) - Method in class com.hazelcast.map.impl.querycache.event.QueryCacheEventDataBuilder
 
withExecutor(Executor) - Static method in class com.hazelcast.spi.impl.InternalCompletableFuture
Creates a new incomplete InternalCompletableFuture that uses the given Executor as default executor for next stages registered with default async methods.
withExpirationTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
WithForcedEviction - Class in com.hazelcast.map.impl.operation
Includes retry logic when a map operation fails to put an entry into IMap due to a NativeOutOfMemoryError.
withGlobalPartitionStrategy(PartitioningStrategy) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService.Builder
 
withHeartbeatIntervalMillis(long) - Method in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
Bootstrap the stats with heartbeats that corresponds to this duration in milliseconds, with a rather high standard deviation (since environment is unknown in the beginning).
withHits(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
withIdTag(String, String) - Method in class com.hazelcast.internal.metrics.impl.MetricTaggerImpl
 
withIdTag(String, String) - Method in interface com.hazelcast.internal.metrics.MetricTagger
Returns a new MetricTagger instance with the given identifier tag added.
withIncludeValue(Boolean) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRequest
 
withInitialOutputBufferSize(int) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService.Builder
 
withInputOutputFactory(InputOutputFactory) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService.Builder
 
withKey(K) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
withLastAccessTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
withLastStoredTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
withLastUpdateTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
withListener(MapListener) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRequest
 
withManagedContext(ManagedContext) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService.Builder
 
withMaxIdle(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
withMaxSampleSize(int) - Method in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
Number of samples to use for calculation of mean and standard deviation of inter-arrival times.
withMetricTag(String) - Method in class com.hazelcast.internal.metrics.impl.MetricTaggerImpl
 
withMetricTag(String) - Method in interface com.hazelcast.internal.metrics.MetricTagger
Returns a new MetricTagger instance with the given metric name tag added.
withMinStdDeviationMillis(long) - Method in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
Minimum standard deviation (in milliseconds) to use for the normal distribution used when calculating phi.
withNotActiveExceptionSupplier(Supplier<RuntimeException>) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService.Builder
 
withNullValue() - Static method in class com.hazelcast.cache.impl.DeferredValue
 
withoutDefaultGroupName(String) - Static method in class com.hazelcast.cp.internal.RaftService
 
withPartitionId(int) - Method in class com.hazelcast.map.impl.querycache.event.QueryCacheEventDataBuilder
 
withPortableFactories(Map<Integer, ? extends PortableFactory>) - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1.AbstractBuilder
 
withPortableVersion(int) - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1.AbstractBuilder
 
withPredicate(Predicate) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRequest
 
withQueryCacheConfig(QueryCacheConfig) - Method in class com.hazelcast.map.impl.querycache.subscriber.QueryCacheRequest
 
withSequence(long) - Method in class com.hazelcast.map.impl.querycache.event.QueryCacheEventDataBuilder
 
withSerializationService(InternalSerializationService) - Method in class com.hazelcast.map.impl.querycache.event.QueryCacheEventDataBuilder
 
withSerializedValue(Data) - Static method in class com.hazelcast.cache.impl.DeferredValue
 
withSplitBrainProtectionSize(int) - Method in class com.hazelcast.config.SplitBrainProtectionConfigBuilder
 
withSuspicionThreshold(double) - Method in class com.hazelcast.config.ProbabilisticSplitBrainProtectionConfigBuilder
Threshold for suspicion (φ) level.
withTag(String, String) - Method in class com.hazelcast.internal.metrics.impl.MetricTaggerImpl
 
withTag(String, String) - Method in interface com.hazelcast.internal.metrics.MetricTagger
Returns a new MetricTagger instance with the given general purpose tag added.
withTransition(T, T, T...) - Method in class com.hazelcast.internal.util.StateMachine
Add a valid transition from one state to one or more states
withTryCatch(ILogger, BiConsumer<T, ? super Throwable>) - Static method in class com.hazelcast.internal.util.ExceptionUtil
Utility to make sure exceptions inside CompletionStage.whenComplete(BiConsumer) are not swallowed.
withTryCatch(ILogger, String, BiConsumer<T, ? super Throwable>) - Static method in class com.hazelcast.internal.util.ExceptionUtil
Utility to make sure exceptions inside CompletionStage.whenComplete(BiConsumer) are not swallowed.
withTtl(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
withValue(V) - Static method in class com.hazelcast.cache.impl.DeferredValue
 
withValue(V) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
withVersion(byte) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService.Builder
 
withVersion(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
wrap() - Method in exception com.hazelcast.client.UndefinedErrorCodeException
 
wrap() - Method in exception com.hazelcast.cp.exception.CannotReplicateException
 
wrap() - Method in exception com.hazelcast.cp.exception.CPGroupDestroyedException
 
wrap() - Method in exception com.hazelcast.cp.exception.CPSubsystemException
 
wrap() - Method in exception com.hazelcast.cp.exception.LeaderDemotedException
 
wrap() - Method in exception com.hazelcast.cp.exception.NotLeaderException
 
wrap() - Method in exception com.hazelcast.cp.exception.StaleAppendRequestException
 
wrap() - Method in exception com.hazelcast.cp.internal.raft.exception.MemberAlreadyExistsException
 
wrap() - Method in exception com.hazelcast.cp.internal.raft.exception.MemberDoesNotExistException
 
wrap() - Method in exception com.hazelcast.cp.internal.raft.exception.MismatchingGroupMembersCommitIndexException
 
wrap() - Method in interface com.hazelcast.spi.impl.operationservice.WrappableException
Returns a new exception of the same type as this exception, using this exception as its cause.
wrapForJoinInternal() - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture.ExceptionalResult
Wraps the AbstractInvocationFuture.ExceptionalResult.cause so that the remote/async throwable is not lost, however is delivered as the cause to an throwable with a local stack trace that makes sense to user code that is synchronizing on joinInternal().
wrapMemoryAllocator(MemoryAllocator) - Method in class com.hazelcast.monitor.impl.GlobalPerIndexStats
 
wrapMemoryAllocator(MemoryAllocator) - Method in class com.hazelcast.monitor.impl.PartitionPerIndexStats
 
wrapMemoryAllocator(MemoryAllocator) - Method in interface com.hazelcast.monitor.impl.PerIndexStats
Wraps the given memory allocator.
WrappableException<T extends RuntimeException> - Interface in com.hazelcast.spi.impl.operationservice
Indicates a runtime exception which can be wrapped in another instance of the same type for the purpose of delivering both a local and an async/remote stack trace, wrapped as the cause of the local exception.
wrapPutAsyncFuture(K, V, Data, Data, ClientInvocationFuture, BiConsumer<V, Throwable>) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
wrapThrowable(Object) - Static method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
wrapToInstanceNotActiveException(RejectedExecutionException) - Method in class com.hazelcast.client.impl.spi.impl.ClientInvocationFuture
 
wrapToInstanceNotActiveException(RejectedExecutionException) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
wrapToInstanceNotActiveException(RejectedExecutionException) - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationFuture
 
write(Cache.Entry<? extends K, ? extends V>) - Method in class com.hazelcast.cache.impl.LatencyTrackingCacheWriter
 
write(OutboundFrame) - Method in class com.hazelcast.client.impl.connection.nio.ClientConnection
 
write(ObjectDataOutput, List<Operation>) - Static method in class com.hazelcast.collection.impl.CollectionTxnUtil
 
write(ObjectDataOutput) - Method in class com.hazelcast.durableexecutor.impl.TaskRingBuffer
 
write(char) - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
write(int) - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
write(double) - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
write(long) - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
write(boolean) - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
write(String) - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
write(OutboundFrame) - Method in interface com.hazelcast.internal.networking.Channel
Queues the OutboundFrame to be written at some point in the future.
write(OutboundFrame) - Method in class com.hazelcast.internal.networking.nio.NioChannel
 
write(OutboundFrame) - Method in class com.hazelcast.internal.networking.nio.NioOutboundPipeline
 
write(int, int) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
write(OutboundFrame) - Method in interface com.hazelcast.internal.nio.Connection
Writes a outbound frame so it can be received by the other side of the connection.
write(OutboundFrame) - Method in class com.hazelcast.internal.nio.tcp.TcpIpConnection
 
write(ObjectDataOutput, Object[]) - Method in class com.hazelcast.internal.serialization.impl.ArrayStreamSerializer
 
write(ObjectDataOutput, ConcurrentSkipListMap<K, V>) - Method in class com.hazelcast.internal.serialization.impl.ConcurrentSkipListMapStreamSerializer
 
write(ObjectDataOutput, ConcurrentSkipListSet<E>) - Method in class com.hazelcast.internal.serialization.impl.ConcurrentSkipListSetStreamSerializer
 
write(ObjectDataOutput, boolean[]) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.BooleanArraySerializer
 
write(ObjectDataOutput, Boolean) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.BooleanSerializer
 
write(ObjectDataOutput, Byte) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.ByteSerializer
 
write(ObjectDataOutput, char[]) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.CharArraySerializer
 
write(ObjectDataOutput, Character) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.CharSerializer
 
write(ObjectDataOutput, double[]) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.DoubleArraySerializer
 
write(ObjectDataOutput, Double) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.DoubleSerializer
 
write(ObjectDataOutput, float[]) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.FloatArraySerializer
 
write(ObjectDataOutput, Float) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.FloatSerializer
 
write(ObjectDataOutput, int[]) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.IntegerArraySerializer
 
write(ObjectDataOutput, Integer) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.IntegerSerializer
 
write(ObjectDataOutput, long[]) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.LongArraySerializer
 
write(ObjectDataOutput, Long) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.LongSerializer
 
write(ObjectDataOutput, Object) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.NullSerializer
 
write(ObjectDataOutput, short[]) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.ShortArraySerializer
 
write(ObjectDataOutput, Short) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.ShortSerializer
 
write(ObjectDataOutput, String[]) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.StringArraySerializer
 
write(ObjectDataOutput, String) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.StringSerializer
 
write(byte[]) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.TheByteArraySerializer
 
write(ObjectDataOutput, UUID) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.UuidSerializer
 
write(ObjectDataOutput, BigDecimal) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.BigDecimalSerializer
 
write(ObjectDataOutput, BigInteger) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.BigIntegerSerializer
 
write(ObjectDataOutput, Class) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.ClassSerializer
 
write(ObjectDataOutput, Date) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.DateSerializer
 
write(ObjectDataOutput, Enum) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.EnumSerializer
 
write(ObjectDataOutput, Externalizable) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.ExternalizableSerializer
 
write(ObjectDataOutput, HazelcastJsonValue) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.HazelcastJsonValueSerializer
 
write(ObjectDataOutput, Object) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.JavaSerializer
 
write(int) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
write(byte[], int, int) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
write(byte[]) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
write(ObjectDataOutput, PriorityBlockingQueue<E>) - Method in class com.hazelcast.internal.serialization.impl.PriorityBlockingQueueStreamSerializer
 
write(ObjectDataOutput, TreeMap<K, V>) - Method in class com.hazelcast.internal.serialization.impl.TreeMapStreamSerializer
 
write(ObjectDataOutput, Set<E>) - Method in class com.hazelcast.internal.serialization.impl.TreeSetStreamSerializer
 
write(T) - Method in interface com.hazelcast.nio.serialization.ByteArraySerializer
Converts given object to byte array
write(ObjectDataOutput, T) - Method in interface com.hazelcast.nio.serialization.StreamSerializer
This method writes object to ObjectDataOutput
WRITE_BEHIND_STATE_HOLDER - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
writeAddEvent(EventJournalConfig, ObjectNamespace, int, Data, Object) - Method in interface com.hazelcast.map.impl.journal.MapEventJournal
Writes an EntryEventType.ADDED to the event journal.
writeAddEvent(EventJournalConfig, ObjectNamespace, int, Data, Object) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
 
writeAll(Collection<Cache.Entry<? extends K, ? extends V>>) - Method in class com.hazelcast.cache.impl.LatencyTrackingCacheWriter
 
writeAttributeValue(Object, ObjectDataOutput) - Static method in class com.hazelcast.internal.nio.IOUtil
 
WriteBehindManager - Class in com.hazelcast.map.impl.mapstore.writebehind
Write behind map store manager.
WriteBehindManager(MapStoreContext) - Constructor for class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindManager
 
WriteBehindProcessor<E> - Interface in com.hazelcast.map.impl.mapstore.writebehind
Write behind processors main contract.
WriteBehindProcessors - Class in com.hazelcast.map.impl.mapstore.writebehind
Static factory which creates a write behind processor.
WriteBehindQueue<E> - Interface in com.hazelcast.map.impl.mapstore.writebehind
A specific queue implementation which is used for write-behind-store operations.
WriteBehindQueues - Class in com.hazelcast.map.impl.mapstore.writebehind
A class providing static factory methods that create write behind queues.
writeBehindStateHolder - Variable in class com.hazelcast.map.impl.operation.MapReplicationOperation
 
WriteBehindStateHolder - Class in com.hazelcast.map.impl.operation
Holder for write-behind-specific state.
WriteBehindStateHolder() - Constructor for class com.hazelcast.map.impl.operation.WriteBehindStateHolder
This constructor exists solely for instantiation by MapDataSerializerHook.
WriteBehindStateHolder(MapReplicationOperation) - Constructor for class com.hazelcast.map.impl.operation.WriteBehindStateHolder
 
WriteBehindStore - Class in com.hazelcast.map.impl.mapstore.writebehind
Write behind map data store implementation.
WriteBehindStore(MapStoreContext, int, WriteBehindProcessor) - Constructor for class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
WriteBehindStore.Sequence - Class in com.hazelcast.map.impl.mapstore.writebehind
The purpose of this class is to provide distinction between flushes caused by eviction and IMap.flush()
writeBoolean(int, boolean) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
writeBoolean(String, boolean) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writeBoolean(boolean) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeBoolean(String, boolean) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive boolean.
writeBooleanArray(String, boolean[]) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writeBooleanArray(boolean[]) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeBooleanArray(boolean[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeBooleanArray(String, boolean[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive boolean-array.
writeByte(int, int) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
writeByte(String, byte) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writeByte(int) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeByte(String, byte) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive byte.
writeByteArray(ObjectDataOutput, byte[]) - Static method in class com.hazelcast.internal.nio.IOUtil
 
writeByteArray(String, byte[]) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writeByteArray(byte[]) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeByteArray(byte[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeByteArray(String, byte[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive byte-array.
writeBytes(String) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeChar(ByteAccessStrategy<R>, R, long, char, boolean) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
writeChar(byte[], int, char, boolean) - Static method in class com.hazelcast.internal.nio.Bits
 
writeChar(int, int) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
writeChar(String, int) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writeChar(int) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeChar(String, int) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive char.
writeCharArray(String, char[]) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writeCharArray(char[]) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeCharArray(char[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeCharArray(String, char[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive char-array.
writeCharB(ByteAccessStrategy<R>, R, long, char) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
writeCharB(byte[], int, char) - Static method in class com.hazelcast.internal.nio.Bits
 
writeCharL(ByteAccessStrategy<R>, R, long, char) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
writeCharL(byte[], int, char) - Static method in class com.hazelcast.internal.nio.Bits
 
writeChars(String) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeCollection(Collection<T>, ObjectDataOutput) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
Writes a collection to an ObjectDataOutput.
writeCreatedEvent(EventJournalConfig, ObjectNamespace, int, Data, Object) - Method in interface com.hazelcast.cache.impl.journal.CacheEventJournal
Writes an CacheEventType.CREATED to the event journal.
writeCreatedEvent(EventJournalConfig, ObjectNamespace, int, Data, Object) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.BigDecimalAverageAggregator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.BigDecimalSumAggregator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.BigIntegerAverageAggregator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.BigIntegerSumAggregator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.CanonicalizingHashSet
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.CountAggregator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.DistinctValuesAggregator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.DoubleAverageAggregator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.DoubleSumAggregator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.FixedSumAggregator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.FloatingPointSumAggregator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.IntegerAverageAggregator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.IntegerSumAggregator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.LongAverageAggregator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.LongSumAggregator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.MaxAggregator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.MaxByAggregator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.MinAggregator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.MinByAggregator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.aggregation.impl.NumberAverageAggregator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.CacheClearResponse
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.CacheEntryIterationResult
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.CacheEventListenerAdaptor
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.CacheEventSet
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.CacheKeyIterationResult
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.CachePartitionEventData
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.event.CachePartitionLostEventFilter
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.journal.DeserializingEventJournalCacheEvent
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.journal.InternalEventJournalCacheEvent
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation.MetaDataResponse
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheNearCacheStateHolder
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.record.CacheDataRecord
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.record.CacheObjectRecord
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.tenantcontrol.CacheDestroyEventContext
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cardinality.impl.CardinalityEstimatorContainer
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.DenseHyperLogLogEncoder
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.HyperLogLogImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cardinality.impl.hyperloglog.impl.SparseHyperLogLogEncoder
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.client.impl.operations.OperationFactoryWrapper
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAssignAndGetUuidsOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAssignAndGetUuidsOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cluster.Address
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cluster.impl.AbstractMember
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cluster.impl.VectorClock
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cluster.MemberAttributeEvent
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.collection.CollectionEvent
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.collection.CollectionEventFilter
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.collection.CollectionItem
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.collection.TxCollectionItem
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.QueueEvent
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.QueueEventFilter
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.QueueItem
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txnqueue.TxQueueItem
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.AbstractWanPublisherConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.AliasedDiscoveryConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.AttributeConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CardinalityEstimatorConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.CollectionConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.DiscoveryConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.DurableExecutorConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.EntryListenerConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.EventJournalConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.EvictionConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ExecutorConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.FlakeIdGeneratorConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.HotRestartConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.IndexConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ItemListenerConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ListenerConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MapConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MapStoreConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MaxSizeConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MergePolicyConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MerkleTreeConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.MultiMapConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.NearCacheConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.NearCachePreloaderConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.PNCounterConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.PredicateConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.QueryCacheConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.QueueConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.QueueStoreConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ReliableTopicConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ReplicatedMapConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.RingbufferConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.RingbufferStoreConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.ScheduledExecutorConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.SplitBrainProtectionConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.TopicConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanBatchReplicationPublisherConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanConsumerConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanReplicationConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanReplicationRef
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.config.WanSyncConfig
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.console.Echo
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.CPGroupInfo
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.CPGroupSummary
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.CPMemberInfo
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.AbstractAtomicLongOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.AddAndGetOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.AlterOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.ApplyOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.CompareAndSetOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.GetAndAddOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.operation.GetAndSetOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.AbstractAtomicRefOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.ApplyOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.CompareAndSetOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.ContainsOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.operation.SetOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.CountDownLatch
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.AbstractCountDownLatchOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.AwaitOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.CountDownOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.countdownlatch.operation.TrySetCountOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.lock.Lock
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.lock.LockEndpoint
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.lock.LockInvocationKey
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.lock.LockOwnershipState
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.GetLockOwnershipStateOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.LockOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.lock.operation.TryLockOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.AcquireInvocationKey
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.AcquirePermitsOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.AvailablePermitsOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.ChangePermitsOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.InitSemaphoreOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.operation.ReleasePermitsOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.Semaphore
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.semaphore.SemaphoreEndpoint
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueSnapshot
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.BlockingResource
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.operation.ExpireWaitKeysOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.ResourceRegistry
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKey
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.spi.blocking.WaitKeyContainer
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.datastructures.spi.operation.DestroyRaftObjectOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.MembershipChangeSchedule.CPGroupMembershipChange
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.MembershipChangeSchedule
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.MetadataRaftGroupSnapshot
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raft.command.DestroyRaftGroupCmd
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raft.impl.command.UpdateRaftGroupMembersCmd
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendFailureResponse
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendRequest
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raft.impl.dto.AppendSuccessResponse
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raft.impl.dto.InstallSnapshot
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raft.impl.dto.PreVoteRequest
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raft.impl.dto.PreVoteResponse
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raft.impl.dto.TriggerLeaderElection
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raft.impl.dto.VoteRequest
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raft.impl.dto.VoteResponse
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raft.impl.log.LogEntry
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raft.impl.log.SnapshotEntry
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.RaftEndpointImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.RaftGroupId
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.GetInitialRaftGroupMembersIfCurrentGroupMemberOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.metadata.AddCPMemberOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.metadata.CompleteDestroyRaftGroupsOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.metadata.CompleteRaftGroupMembershipChangesOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.metadata.CreateRaftGroupOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.metadata.ForceDestroyRaftGroupOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetActiveCPMembersOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetActiveRaftGroupByNameOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetActiveRaftGroupIdsOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetDestroyingRaftGroupIdsOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetMembershipChangeScheduleOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetRaftGroupIdsOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.metadata.GetRaftGroupOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.metadata.InitMetadataRaftGroupOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.metadata.RemoveCPMemberOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.metadata.TriggerDestroyRaftGroupOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.NotifyTermChangeOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.snapshot.RestoreSnapshotOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.session.CPSessionInfo
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.session.operation.CloseInactiveSessionsOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.session.operation.CloseSessionOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.session.operation.CreateSessionOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.session.operation.ExpireSessionsOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.session.operation.GenerateThreadIdOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.session.operation.GetSessionsOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.session.operation.HeartbeatSessionOp
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.session.SessionResponse
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.UnsafeModePartitionState
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.executor.impl.RunnableAdapter
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.instance.EndpointQualifier
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.ascii.rest.RestValue
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.BindMessage
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.ClusterStateChange
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.ClusterStateTransactionLogRecord
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.ConfigCheck
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.ExtendedBindMessage
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.JoinMessage
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.JoinRequest
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.MembersView
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.MembersViewMetadata
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.SplitBrainJoinMessage
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.MemberInfo
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.crdt.pncounter.operations.CRDTTimestampedLong
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.crdt.pncounter.PNCounterImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.journal.DeserializingEntry
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.journal.EventJournalInitialSubscriberState
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.locksupport.LockStoreImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.management.dto.MapConfigDTO
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.management.dto.PermissionConfigDTO
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.CacheBrowserEntryView
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest.GetCacheEntryViewEntryProcessor
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.BatchNearCacheInvalidation
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.Invalidation
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.SingleNearCacheInvalidation
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.MigrationInfo
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.MigrationStateImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.NonFragmentedServiceNamespace
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.PartitionLostEventImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.PartitionReplica
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.PartitionRuntimeState
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.ReplicaFragmentMigrationState
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.ReplicaMigrationEventImpl
 
writeData(Data) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.services.DistributedObjectNamespace
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.internal.usercodedeployment.impl.ClassData
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.eviction.LFUEvictionPolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.eviction.LRUEvictionPolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.eviction.RandomEvictionPolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.EntryEventFilter
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.EntryRemovingProcessor
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.event.EntryEventData
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.event.MapEventData
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.event.MapPartitionEventData
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.EventListenerFilter
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.iterator.AbstractCursor
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.journal.DeserializingEventJournalMapEvent
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.journal.InternalEventJournalMapEvent
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.LazyMapEntry
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.MapEntries
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.MapKeySet
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.MapPartitionLostEventFilter
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.MapValueCollection
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.MerkleTreeNodeEntries
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.nearcache.invalidation.UuidFilter
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.AddIndexOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.ClearOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.ContainsValueOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.EvictAllOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.IsEmptyOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.IsPartitionLoadedOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.KeyLoadStatusOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.MapFlushOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.MapGetAllOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.MapGetInvalidationMetaDataOperation.MetaDataResponse
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.MapLoadAllOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.MapNearCacheStateHolder
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.MapReplicationStateHolder
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.MergeOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation.InterceptorInfo
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.PutAllPartitionAwareOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.SizeOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.WriteBehindStateHolder
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.query.AggregationResult
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.query.Query
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.query.QueryEventFilter
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.query.QueryResult
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.query.QueryResultRow
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.query.ResultSegment
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.query.Target
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.querycache.event.BatchEventData
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.querycache.event.LocalCacheWideEventData
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.querycache.event.LocalEntryEventData
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.MadePublishableOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.record.RecordInfo
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.record.RecordReplicationInfo
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.SimpleEntryView
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.tx.MapTransactionLogRecord
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.tx.VersionedValue
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.map.impl.wan.WanMapEntryView
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.MultiMapEventFilter
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.MultiMapMergeContainer
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.MultiMapRecord
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.operations.EntrySetResponse
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
 
writeData(Data) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeData(ObjectDataOutput) - Method in interface com.hazelcast.nio.serialization.DataSerializable
Writes object fields to output stream
writeData(ObjectDataOutput) - Method in class com.hazelcast.partition.PartitionAwareKey
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.projection.impl.IdentityProjection
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.projection.impl.MultiAttributeProjection
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.projection.impl.SingleAttributeProjection
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.CompositeValue
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.MapIndexInfo
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.PredicateBuilderImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.predicates.AndPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.predicates.FalsePredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.predicates.InPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.predicates.InstanceOfPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.predicates.LikePredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.predicates.NotEqualPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.predicates.NotPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.predicates.OrPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.predicates.PagingPredicateImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.predicates.PartitionPredicateImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.predicates.RegexPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.predicates.SqlPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.impl.predicates.TruePredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.MergeOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.PutAllOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.VersionResponsePair
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.HashMapAdapter
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.NamedTaskDecorator
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetAllScheduledOnPartitionOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledRunnableAdapter
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskDescriptor
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskHandlerImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskResult
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.ScheduledTaskStatisticsImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.TaskDefinition
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventEnvelope
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.eventservice.impl.TrueEventFilter
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.merge.AbstractCollectionMergingValueImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.merge.AbstractMergingEntryImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.merge.AbstractMergingValueImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.merge.AbstractSplitBrainMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.merge.CacheMergingEntryImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.merge.MapMergingEntryImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.merge.MultiMapMergingEntryImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.merge.ReplicatedMapMergingEntryImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.merge.RingbufferMergingValueImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.operationservice.BinaryOperationFactory
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation.PartitionResponse
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.ErrorResponse
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.NormalResponse
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.operationservice.OperationControl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectEventPacket
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.SerializableList
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.tenantcontrol.NoopTenantControl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicMessage
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.transaction.impl.xa.SerializableXID
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.transaction.impl.xa.XATransactionDTO
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.transaction.TransactionOptions
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.version.MemberVersion
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.version.Version
 
writeDouble(ByteAccessStrategy<R>, R, long, double, boolean) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
writeDouble(int, double) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
writeDouble(double, ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
writeDouble(int, double, ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
writeDouble(String, double) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writeDouble(double) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeDouble(String, double) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive double.
writeDoubleArray(String, double[]) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writeDoubleArray(double[]) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeDoubleArray(double[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeDoubleArray(String, double[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive double array.
writeDoubleB(ByteAccessStrategy<R>, R, long, double) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
writeDoubleL(ByteAccessStrategy<R>, R, long, double) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
writeEntry(String) - Method in interface com.hazelcast.internal.diagnostics.DiagnosticsLogWriter
 
writeEntry(String) - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
writeEvictEvent(EventJournalConfig, ObjectNamespace, int, Data, Object) - Method in interface com.hazelcast.cache.impl.journal.CacheEventJournal
Writes an CacheEventType.EVICTED to the event journal.
writeEvictEvent(EventJournalConfig, ObjectNamespace, int, Data, Object) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
 
writeEvictEvent(EventJournalConfig, ObjectNamespace, int, Data, Object) - Method in interface com.hazelcast.map.impl.journal.MapEventJournal
Writes an EntryEventType.EVICTED to the event journal.
writeEvictEvent(EventJournalConfig, ObjectNamespace, int, Data, Object) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
 
writeExpiredEvent(EventJournalConfig, ObjectNamespace, int, Data, Object) - Method in interface com.hazelcast.cache.impl.journal.CacheEventJournal
Writes an CacheEventType.EXPIRED to the event journal.
writeExpiredEvent(EventJournalConfig, ObjectNamespace, int, Data, Object) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
 
writeFactories(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.PreJoinCacheConfig
 
writeFactories(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
 
writeFloat(ByteAccessStrategy<R>, R, long, float, boolean) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
writeFloat(int, float) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
writeFloat(float, ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
writeFloat(int, float, ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
writeFloat(String, float) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writeFloat(float) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeFloat(String, float) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive float.
writeFloatArray(String, float[]) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writeFloatArray(float[]) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeFloatArray(float[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeFloatArray(String, float[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive float array.
writeFloatB(ByteAccessStrategy<R>, R, long, float) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
writeFloatL(ByteAccessStrategy<R>, R, long, float) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
writeInt(ByteAccessStrategy<R>, R, long, int, boolean) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
writeInt(byte[], int, int, boolean) - Static method in class com.hazelcast.internal.nio.Bits
 
writeInt(int, int) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
writeInt(int, ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
writeInt(int, int, ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
writeInt(String, int) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writeInt(int) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeInt(String, int) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive int.
writeIntArray(String, int[]) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writeIntArray(int[]) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeIntArray(int[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeIntArray(String, int[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive int-array.
writeIntB(ByteAccessStrategy<R>, R, long, int) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
writeIntB(byte[], int, int) - Static method in class com.hazelcast.internal.nio.Bits
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalReadOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.AddCacheConfigOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
Deprecated.
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheDestroyOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheEntryIteratorOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheExpireBatchBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheGetInvalidationMetaDataOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheGetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheKeyIteratorOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CachePutBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheSetExpiryPolicyBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.CacheSetExpiryPolicyOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.KeyBasedCacheOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.MutatingCacheOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.operation.OnJoinCacheOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cardinality.impl.operations.AbstractCardinalityEstimatorOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cardinality.impl.operations.AggregateBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cardinality.impl.operations.AggregateOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cardinality.impl.operations.MergeBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cardinality.impl.operations.MergeOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cardinality.impl.operations.ReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionClearBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionCompareAndRemoveOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionContainsOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionMergeBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionMergeOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.list.operations.ListAddAllOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.list.operations.ListAddOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.list.operations.ListGetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.list.operations.ListIndexOfOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.list.operations.ListRemoveOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.list.operations.ListSetBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.list.operations.ListSetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.list.operations.ListSubOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.operations.AddAllBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.operations.AddAllOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.operations.ClearBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.operations.ContainsOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.operations.DrainBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.operations.DrainOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.operations.OfferBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.operations.PollBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.operations.QueueMergeBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.operations.QueueMergeOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.operations.QueueReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.operations.RemoveBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.queue.operations.RemoveOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveAddOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveRemoveOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTransactionRollbackOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.BaseTxnQueueOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.QueueTransactionRollbackOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPeekOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.operation.ChangeRaftGroupMembershipOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.operation.DefaultRaftReplicateOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.operation.integration.AppendFailureResponseOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.operation.integration.AppendRequestOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.operation.integration.AppendSuccessResponseOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.operation.integration.AsyncRaftOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.operation.integration.InstallSnapshotOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.operation.integration.PreVoteRequestOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.operation.integration.PreVoteResponseOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.operation.integration.TriggerLeaderElectionOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.operation.integration.VoteRequestOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.operation.integration.VoteResponseOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.operation.RaftQueryOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.operation.RaftReplicateOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.operation.RestartCPMemberOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.operation.TransferLeadershipOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.operation.unsafe.AbstractUnsafeRaftOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.operation.unsafe.UnsafeSnapshotReplicationOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.operation.unsafe.UnsafeStateReplicationOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.metadata.CreateRaftNodeOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.metadata.DestroyRaftNodesOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.metadata.PublishActiveCPMembersOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cp.internal.raftop.metadata.RaftServicePreJoinOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.durableexecutor.impl.operations.DisposeResultBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.durableexecutor.impl.operations.DisposeResultOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.durableexecutor.impl.operations.PutResultBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.durableexecutor.impl.operations.PutResultOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.durableexecutor.impl.operations.ReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.durableexecutor.impl.operations.RetrieveResultOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.durableexecutor.impl.operations.TaskBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.durableexecutor.impl.operations.TaskOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.BeforeJoinCheckFailureOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.CommitClusterStateOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.ConfigMismatchOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.ExplicitSuspicionOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.FetchMembersViewOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.HeartbeatComplaintOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.HeartbeatOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.JoinRequestOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.LockClusterStateOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.MasterResponseOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.MemberAttributeChangedOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.MembersUpdateOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.MergeClustersOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.OnJoinOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.RollbackClusterStateOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.SplitBrainMergeValidationOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.TriggerExplicitSuspicionOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.WhoisMasterOp
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.crdt.AbstractCRDTReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.crdt.pncounter.operations.AbstractPNCounterOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.crdt.pncounter.operations.AddOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.crdt.pncounter.operations.GetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.dynamicconfig.AddDynamicConfigOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigPreJoinOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.journal.EventJournalReadOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.locksupport.operations.AbstractLockOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.locksupport.operations.LocalLockCleanupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.locksupport.operations.LockBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.locksupport.operations.LockReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.locksupport.operations.UnlockBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.locksupport.operations.UnlockIfLeaseExpiredOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.locksupport.operations.UnlockOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.longregister.operations.AbstractLongRegisterOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.longregister.operations.AddAndGetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.longregister.operations.AddBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.longregister.operations.GetAndAddOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.longregister.operations.GetAndSetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.longregister.operations.LongRegisterReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.longregister.operations.SetBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.longregister.operations.SetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.management.operation.ScriptExecutorOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.management.operation.SetLicenseOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.management.operation.UpdateManagementCenterUrlOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.management.operation.UpdateMapConfigOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.management.operation.UpdatePermissionConfigOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.metrics.managementcenter.ReadMetricsOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.operation.FinalizeMigrationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.operation.MigrationCommitOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.operation.MigrationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.operation.MigrationRequestOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.operation.PartitionBackupReplicaAntiEntropyOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRequest
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncResponse
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.operation.PartitionReplicaSyncRetryResponse
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.operation.PartitionStateOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.operation.PartitionStateVersionCheckOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.operation.PromotionCommitOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.partition.operation.PublishCompletedMigrationsOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.usercodedeployment.impl.operation.ClassDataFinderOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.internal.usercodedeployment.impl.operation.DeployClassesOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.journal.MapEventJournalReadOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.AddIndexBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.AddIndexOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.AwaitMapFlushOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.ContainsValueOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.DeleteOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.EntryBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.EntryOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.EvictBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.EvictBatchBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.EvictOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.GetAllOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.KeyLoadStatusOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.LoadAllOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.LoadMapOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.MapFetchEntriesOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.MapFetchKeysOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.MapFetchWithQueryOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.MapFlushBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.MapGetInvalidationMetaDataOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.MapReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.MergeOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.MultipleEntryBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.MultipleEntryWithPredicateBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.MultipleEntryWithPredicateOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.NotifyMapFlushOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.PutAllBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.PutAllOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.PutIfAbsentWithExpiryOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.PutTransientWithExpiryOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.PutWithExpiryOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.ReadonlyKeyBasedMapOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.RemoveBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.RemoveFromLoadAllOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.RemoveIfSameOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.SetTtlBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.SetTtlOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.SetWithExpiryOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.query.QueryOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.query.QueryPartitionOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.DestroyQueryCacheOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.MadePublishableOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.PublisherCreateOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.ReadAndResetAccumulatorOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.querycache.subscriber.operation.SetReadCursorOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.tx.TxnDeleteBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.tx.TxnPrepareBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.tx.TxnRollbackBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.tx.TxnSetBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.tx.TxnUnlockBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.operations.AbstractBackupAwareMultiMapOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.operations.AbstractKeyBasedMultiMapOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.operations.AbstractMultiMapOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.operations.MergeBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.operations.MergeOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.operations.MultiMapReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.operations.PutBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.operations.PutOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.operations.RemoveBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.txn.TxnCommitBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.txn.TxnPutBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.CheckReplicaVersionOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsKeyOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsValueOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.EntrySetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.GetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.IsEmptyOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.KeySetOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.MergeOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.PutAllOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.PutOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.RemoveOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateToCallerOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.RequestMapDataOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.SizeOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.SyncReplicatedMapDataOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.replicatedmap.impl.operation.ValuesOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.ringbuffer.impl.operations.AbstractRingBufferOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.ringbuffer.impl.operations.AddBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.ringbuffer.impl.operations.GenericOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.ringbuffer.impl.operations.MergeBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.ringbuffer.impl.operations.MergeOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.ringbuffer.impl.operations.ReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.AbstractSchedulerOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.CancelTaskBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.CancelTaskOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.DisposeBackupTaskOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.DisposeTaskOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetDelayOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetResultOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.GetStatisticsOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.IsCanceledOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.IsDoneOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.MergeBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.MergeOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.ReplicationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.ResultReadyNotifyOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.ScheduleTaskBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.ScheduleTaskOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.scheduledexecutor.impl.operations.SyncStateOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.OnJoinRegistrationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.SendEventOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.operationservice.AbstractLocalOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.operationservice.AbstractNamedOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.operationservice.Operation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.DistributedObjectDestroyOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.InitializeDistributedObjectOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.PostJoinProxyOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.topic.impl.PublishOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.transaction.impl.operations.BroadcastTxRollbackOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.transaction.impl.operations.PurgeTxBackupLogOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.transaction.impl.operations.ReplicateTxBackupLogOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.transaction.impl.operations.RollbackTxBackupLogOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionBackupOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.transaction.impl.xa.operations.XaReplicationOperation
 
writeInternalImpl(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.FinalizeJoinOp
 
writeInternalImpl(ObjectDataOutput) - Method in class com.hazelcast.internal.cluster.impl.operations.MembersUpdateOp
 
writeInternalImpl(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.DeregistrationOperation
 
writeInternalImpl(ObjectDataOutput) - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.RegistrationOperation
 
writeIntL(ByteAccessStrategy<R>, R, long, int) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
writeIntL(byte[], int, int) - Static method in class com.hazelcast.internal.nio.Bits
 
writeIntL(ByteBuffer, int, int) - Static method in class com.hazelcast.internal.nio.Bits
 
writeKeyValueEntry(String, String) - Method in interface com.hazelcast.internal.diagnostics.DiagnosticsLogWriter
 
writeKeyValueEntry(String, double) - Method in interface com.hazelcast.internal.diagnostics.DiagnosticsLogWriter
 
writeKeyValueEntry(String, long) - Method in interface com.hazelcast.internal.diagnostics.DiagnosticsLogWriter
 
writeKeyValueEntry(String, boolean) - Method in interface com.hazelcast.internal.diagnostics.DiagnosticsLogWriter
 
writeKeyValueEntry(String, String) - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
writeKeyValueEntry(String, double) - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
writeKeyValueEntry(String, long) - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
writeKeyValueEntry(String, boolean) - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
writeKeyValueEntryAsDateTime(String, long) - Method in interface com.hazelcast.internal.diagnostics.DiagnosticsLogWriter
 
writeKeyValueEntryAsDateTime(String, long) - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
writeKeyValueTypes(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.PreJoinCacheConfig
 
writeKeyValueTypes(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
 
writeLeaves(DataOutput, MerkleTreeView) - Static method in class com.hazelcast.wan.impl.merkletree.MerkleTreeUtil
Writes the hashes of the leaves of a Merkle tree into the provided DataOutput
writeList(List<T>, ObjectDataOutput) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
Writes a list to an ObjectDataOutput.
writeListenerConfigurations(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.PreJoinCacheConfig
 
writeListenerConfigurations(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
 
writeLoadEvent(EventJournalConfig, ObjectNamespace, int, Data, Object) - Method in interface com.hazelcast.map.impl.journal.MapEventJournal
Writes an EntryEventType.LOADED to the event journal.
writeLoadEvent(EventJournalConfig, ObjectNamespace, int, Data, Object) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
 
writeLong(ByteAccessStrategy<R>, R, long, long, boolean) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
writeLong(byte[], int, long, boolean) - Static method in class com.hazelcast.internal.nio.Bits
 
writeLong(int, long) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
writeLong(long, ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
writeLong(int, long, ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
writeLong(String, long) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writeLong(long) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeLong(String, long) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive long.
writeLongArray(String, long[]) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writeLongArray(long[]) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeLongArray(long[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeLongArray(String, long[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive long-array.
writeLongB(ByteAccessStrategy<R>, R, long, long) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
writeLongB(byte[], int, long) - Static method in class com.hazelcast.internal.nio.Bits
 
writeLongL(ByteAccessStrategy<R>, R, long, long) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
writeLongL(byte[], int, long) - Static method in class com.hazelcast.internal.nio.Bits
 
writeMap(Map<K, V>, ObjectDataOutput) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
 
writeNullableCollection(Collection<T>, ObjectDataOutput) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
Writes a collection to an ObjectDataOutput.
writeNullableList(List<T>, ObjectDataOutput) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
Writes a list to an ObjectDataOutput.
writeNullableMap(Map<K, V>, ObjectDataOutput) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
Writes a map to given ObjectDataOutput.
writeNullablePartitionIdSet(PartitionIdSet, ObjectDataOutput) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
Writes a nullable PartitionIdSet to the given data output.
writeNullPortable(String, int, int) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writeNullPortable(String, int, int) - Method in interface com.hazelcast.nio.serialization.PortableWriter
To write a null portable value, user needs to provide class and factoryIds of related class.
writeObject(ObjectDataOutput, Object) - Static method in class com.hazelcast.internal.nio.IOUtil
 
writeObject(ObjectDataOutput, Object) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
 
writeObject(Object) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeObject(ObjectDataOutput, Object) - Method in interface com.hazelcast.internal.serialization.InternalSerializationService
 
writeObject(Object) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writePortable(String, Portable) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writePortable(PortableWriter) - Method in class com.hazelcast.map.impl.querycache.accumulator.AccumulatorInfo
 
writePortable(PortableWriter) - Method in interface com.hazelcast.nio.serialization.Portable
Serialize this portable object using PortableWriter
writePortable(String, Portable) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a Portable.
writePortable(PortableWriter) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
 
writePortable(PortableWriter) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeys
 
writePortable(PortableWriter) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
 
writePortable(PortableWriter) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapValueCollection
 
writePortable(PortableWriter) - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
 
writePortable(PortableWriter) - Method in class com.hazelcast.security.SimpleTokenCredentials
 
writePortable(PortableWriter) - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
writePortable(PortableWriter) - Method in class com.hazelcast.spi.impl.PortableCachePartitionLostEvent
 
writePortable(PortableWriter) - Method in class com.hazelcast.spi.impl.PortableCollection
 
writePortable(PortableWriter) - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
 
writePortable(PortableWriter) - Method in class com.hazelcast.spi.impl.PortableEntryEvent
 
writePortable(PortableWriter) - Method in class com.hazelcast.spi.impl.PortableItemEvent
 
writePortable(PortableWriter) - Method in class com.hazelcast.spi.impl.PortableMapPartitionLostEvent
 
writePortable(PortableWriter) - Method in class com.hazelcast.spi.impl.PortablePartitionLostEvent
 
writePortableArray(String, Portable[]) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writePortableArray(String, Portable[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a an array of Portables.
writePortableInternal(PortableWriter) - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
writeQueue - Variable in class com.hazelcast.internal.networking.nio.NioOutboundPipeline
 
WriterConfig - Class in com.hazelcast.internal.json
Controls the formatting of the JSON output.
WriterConfig() - Constructor for class com.hazelcast.internal.json.WriterConfig
 
writeRemoveEvent(EventJournalConfig, ObjectNamespace, int, Data, Object) - Method in interface com.hazelcast.cache.impl.journal.CacheEventJournal
Writes an CacheEventType.REMOVED to the event journal.
writeRemoveEvent(EventJournalConfig, ObjectNamespace, int, Data, Object) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
 
writeRemoveEvent(EventJournalConfig, ObjectNamespace, int, Data, Object) - Method in interface com.hazelcast.map.impl.journal.MapEventJournal
Writes an EntryEventType.REMOVED to the event journal.
writeRemoveEvent(EventJournalConfig, ObjectNamespace, int, Data, Object) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
 
writeResponse(ManagementCenterService, JsonObject) - Method in class com.hazelcast.internal.management.request.ChangeClusterStateRequest
 
writeResponse(ManagementCenterService, JsonObject) - Method in class com.hazelcast.internal.management.request.ChangeWanStateRequest
 
writeResponse(ManagementCenterService, JsonObject) - Method in class com.hazelcast.internal.management.request.ClearWanQueuesRequest
 
writeResponse(ManagementCenterService, JsonObject) - Method in class com.hazelcast.internal.management.request.ClusterPropsRequest
 
writeResponse(ManagementCenterService, JsonObject) - Method in class com.hazelcast.internal.management.request.ConsoleCommandRequest
 
writeResponse(ManagementCenterService, JsonObject) - Method in interface com.hazelcast.internal.management.request.ConsoleRequest
 
writeResponse(ManagementCenterService, JsonObject) - Method in class com.hazelcast.internal.management.request.ExecuteScriptRequest
 
writeResponse(ManagementCenterService, JsonObject) - Method in class com.hazelcast.internal.management.request.ForceStartNodeRequest
 
writeResponse(ManagementCenterService, JsonObject) - Method in class com.hazelcast.internal.management.request.GetCacheEntryRequest
 
writeResponse(ManagementCenterService, JsonObject) - Method in class com.hazelcast.internal.management.request.GetClusterStateRequest
 
writeResponse(ManagementCenterService, JsonObject) - Method in class com.hazelcast.internal.management.request.GetMapEntryRequest
 
writeResponse(ManagementCenterService, JsonObject) - Method in class com.hazelcast.internal.management.request.GetMemberSystemPropertiesRequest
 
writeResponse(ManagementCenterService, JsonObject) - Method in class com.hazelcast.internal.management.request.MapConfigRequest
 
writeResponse(ManagementCenterService, JsonObject) - Method in class com.hazelcast.internal.management.request.MemberConfigRequest
 
writeResponse(ManagementCenterService, JsonObject) - Method in class com.hazelcast.internal.management.request.PromoteMemberRequest
 
writeResponse(ManagementCenterService, JsonObject) - Method in class com.hazelcast.internal.management.request.RunGcRequest
 
writeResponse(ManagementCenterService, JsonObject) - Method in class com.hazelcast.internal.management.request.ShutdownClusterRequest
 
writeResponse(ManagementCenterService, JsonObject) - Method in class com.hazelcast.internal.management.request.ThreadDumpRequest
 
writeResponse(ManagementCenterService, JsonObject) - Method in class com.hazelcast.internal.management.request.TriggerPartialStartRequest
 
writeResponse(ManagementCenterService, JsonObject) - Method in class com.hazelcast.internal.management.request.WanCheckConsistencyRequest
 
writeSectionKeyValue(String, long, String, long) - Method in interface com.hazelcast.internal.diagnostics.DiagnosticsLogWriter
 
writeSectionKeyValue(String, long, String, double) - Method in interface com.hazelcast.internal.diagnostics.DiagnosticsLogWriter
 
writeSectionKeyValue(String, long, String, String) - Method in interface com.hazelcast.internal.diagnostics.DiagnosticsLogWriter
 
writeSectionKeyValue(String, long, String, long) - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
writeSectionKeyValue(String, long, String, double) - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
writeSectionKeyValue(String, long, String, String) - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriterImpl
 
writeShort(ByteAccessStrategy<R>, R, long, short, boolean) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
writeShort(byte[], int, short, boolean) - Static method in class com.hazelcast.internal.nio.Bits
 
writeShort(int, int) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
writeShort(int, ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
writeShort(int, int, ByteOrder) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
writeShort(String, short) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writeShort(int) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeShort(String, short) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive short.
writeShortArray(String, short[]) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writeShortArray(short[]) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeShortArray(short[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeShortArray(String, short[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a primitive short-array.
writeShortB(ByteAccessStrategy<R>, R, long, short) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
writeShortB(byte[], int, short) - Static method in class com.hazelcast.internal.nio.Bits
 
writeShortL(ByteAccessStrategy<R>, R, long, short) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
writeShortL(byte[], int, short) - Static method in class com.hazelcast.internal.nio.Bits
 
writeShortL(ByteBuffer, int, short) - Static method in class com.hazelcast.internal.nio.Bits
 
writeTenant(ObjectDataOutput) - Method in class com.hazelcast.cache.impl.PreJoinCacheConfig
 
writeTenant(ObjectDataOutput) - Method in class com.hazelcast.config.CacheConfig
 
writeThrough - Variable in class com.hazelcast.client.impl.protocol.codec.DynamicConfigAddCacheConfigCodec.RequestParameters
true to enable write through to a CacheWriter
writeThroughCache(Data, Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
writeThroughEnabled(boolean) - Method in class com.hazelcast.internal.networking.nio.NioNetworking.Context
 
WriteThroughEntry(K, V) - Constructor for class com.hazelcast.internal.util.ConcurrentReferenceHashMap.WriteThroughEntry
 
WriteThroughManager - Class in com.hazelcast.map.impl.mapstore.writethrough
Write through map store manager.
WriteThroughManager(MapStoreContext) - Constructor for class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughManager
 
WriteThroughStore - Class in com.hazelcast.map.impl.mapstore.writethrough
Write through map data store implementation.
WriteThroughStore(MapStoreContext) - Constructor for class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
writeTo(ByteBuffer, ClientMessage) - Method in class com.hazelcast.client.impl.protocol.ClientMessageWriter
 
writeTo(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.BulkGetCommand
 
writeTo(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.DeleteCommand
 
writeTo(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.ErrorCommand
 
writeTo(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.GetCommand
 
writeTo(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.IncrementCommand
 
writeTo(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.SetCommand
 
writeTo(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.SimpleCommand
 
writeTo(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.StatsCommand
 
writeTo(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.TouchCommand
 
writeTo(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.VersionCommand
 
writeTo(ByteBuffer) - Method in class com.hazelcast.internal.ascii.NoOpCommand
 
writeTo(ByteBuffer) - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
 
writeTo(ByteBuffer) - Method in interface com.hazelcast.internal.ascii.TextCommand
 
writeTo(Writer) - Method in class com.hazelcast.internal.json.JsonValue
Writes the JSON representation of this value to the given writer in its minimal form, without any additional whitespace.
writeTo(Writer, WriterConfig) - Method in class com.hazelcast.internal.json.JsonValue
Writes the JSON representation of this value to the given writer using the given formatting.
writeTo(Packet, ByteBuffer) - Method in class com.hazelcast.internal.nio.PacketIOHelper
Writes the packet data to the supplied ByteBuffer, up to the buffer's limit.
writeTo(MigrationInfo.MigrationStatus, DataOutput) - Static method in enum com.hazelcast.internal.partition.MigrationInfo.MigrationStatus
 
writeTo(MigrationEndpoint, DataOutput) - Static method in enum com.hazelcast.spi.partition.MigrationEndpoint
 
writeUpdateEvent(EventJournalConfig, ObjectNamespace, int, Data, Object, Object) - Method in interface com.hazelcast.cache.impl.journal.CacheEventJournal
Writes an CacheEventType.UPDATED to the event journal.
writeUpdateEvent(EventJournalConfig, ObjectNamespace, int, Data, Object, Object) - Method in class com.hazelcast.cache.impl.journal.RingbufferCacheEventJournalImpl
 
writeUpdateEvent(EventJournalConfig, ObjectNamespace, int, Data, Object, Object) - Method in interface com.hazelcast.map.impl.journal.MapEventJournal
Writes an EntryEventType.UPDATED to the event journal.
writeUpdateEvent(EventJournalConfig, ObjectNamespace, int, Data, Object, Object) - Method in class com.hazelcast.map.impl.journal.RingbufferMapEventJournalImpl
 
writeUTF(String, String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writeUTF(String) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeUTF(String, String) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes an UTF string.
writeUtf8Char(ByteAccessStrategy<R>, R, long, int) - Static method in class com.hazelcast.internal.memory.impl.EndiannessUtil
 
writeUtf8Char(byte[], int, int) - Static method in class com.hazelcast.internal.nio.Bits
 
writeUTFArray(String, String[]) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
 
writeUTFArray(String[]) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
 
writeUTFArray(String[]) - Method in interface com.hazelcast.nio.ObjectDataOutput
 
writeUTFArray(String, String[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
Writes a String-array.
writeUUID(DataOutput, UUID) - Static method in class com.hazelcast.internal.util.UUIDSerializationUtil
 
writeValue(ObjectDataOutput, Long) - Method in class com.hazelcast.cp.internal.datastructures.atomiclong.AtomicLongSnapshot
 
writeValue(ObjectDataOutput, Data) - Method in class com.hazelcast.cp.internal.datastructures.atomicref.AtomicRefSnapshot
 
writeValue(ObjectDataOutput, T) - Method in class com.hazelcast.cp.internal.datastructures.spi.atomic.RaftAtomicValueSnapshot
 
writeZeroBytes(int) - Method in interface com.hazelcast.internal.nio.BufferObjectDataOutput
 
WRONG_TARGET - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
WrongTargetException - Exception in com.hazelcast.spi.exception
A RetryableHazelcastException indicating that an operation is executed on a wrong member.
WrongTargetException(Member, Member, int, int, String) - Constructor for exception com.hazelcast.spi.exception.WrongTargetException
 
WrongTargetException(Member, Member, int, int, String, String) - Constructor for exception com.hazelcast.spi.exception.WrongTargetException
 
WrongTargetException(String) - Constructor for exception com.hazelcast.spi.exception.WrongTargetException
 

X

XA - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
XA_REPLICATION - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
XA_TRANSACTION_DTO - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
XAClearRemoteTransactionMessageTask - Class in com.hazelcast.client.impl.protocol.task.transaction
 
XAClearRemoteTransactionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transaction.XAClearRemoteTransactionMessageTask
 
XACollectTransactionsMessageTask - Class in com.hazelcast.client.impl.protocol.task.transaction
 
XACollectTransactionsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transaction.XACollectTransactionsMessageTask
 
XAFinalizeTransactionMessageTask - Class in com.hazelcast.client.impl.protocol.task.transaction
 
XAFinalizeTransactionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transaction.XAFinalizeTransactionMessageTask
 
XaReplicationOperation - Class in com.hazelcast.transaction.impl.xa.operations
 
XaReplicationOperation() - Constructor for class com.hazelcast.transaction.impl.xa.operations.XaReplicationOperation
 
XaReplicationOperation(List<XATransactionDTO>, int, int) - Constructor for class com.hazelcast.transaction.impl.xa.operations.XaReplicationOperation
 
XAResourceImpl - Class in com.hazelcast.transaction.impl.xa
Server side XaResource implementation
XAResourceImpl(NodeEngine, XAService) - Constructor for class com.hazelcast.transaction.impl.xa.XAResourceImpl
 
XAResourceProxy - Class in com.hazelcast.client.impl.proxy.txn.xa
Client side XaResource implementation
XAResourceProxy(String, String, ClientContext) - Constructor for class com.hazelcast.client.impl.proxy.txn.xa.XAResourceProxy
 
XAService - Class in com.hazelcast.transaction.impl.xa
Provides XAResource to the user via proxyService Holds all prepared state xa transactions
XAService(NodeEngineImpl) - Constructor for class com.hazelcast.transaction.impl.xa.XAService
 
XATransaction - Class in com.hazelcast.transaction.impl.xa
XA Transaction implementation.
XATransaction(NodeEngine, Xid, UUID, int, boolean) - Constructor for class com.hazelcast.transaction.impl.xa.XATransaction
 
XATransaction(NodeEngine, Collection<TransactionLogRecord>, UUID, SerializableXID, UUID, long, long) - Constructor for class com.hazelcast.transaction.impl.xa.XATransaction
 
XATransactionClearRemoteCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
XATransactionClearRemoteCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
XATransactionClearRemoteCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
XATransactionCollectTransactionsCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
XATransactionCollectTransactionsCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
XATransactionCollectTransactionsCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
XATransactionCommitCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
XATransactionCommitCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
XATransactionCommitCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
XATransactionCommitMessageTask - Class in com.hazelcast.client.impl.protocol.task.transaction
 
XATransactionCommitMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCommitMessageTask
 
XATransactionContextImpl - Class in com.hazelcast.transaction.impl.xa
 
XATransactionContextImpl(NodeEngineImpl, Xid, UUID, int, boolean) - Constructor for class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
 
XATransactionContextProxy - Class in com.hazelcast.client.impl.proxy.txn.xa
Provides a context to perform transactional operations: beginning/committing transactions, but also retrieving transactional data-structures like the TransactionalMap.
XATransactionContextProxy(ClientTransactionManagerServiceImpl, Xid, int) - Constructor for class com.hazelcast.client.impl.proxy.txn.xa.XATransactionContextProxy
 
XATransactionCreateCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
XATransactionCreateCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
XATransactionCreateCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
XATransactionCreateMessageTask - Class in com.hazelcast.client.impl.protocol.task.transaction
 
XATransactionCreateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCreateMessageTask
 
XATransactionDTO - Class in com.hazelcast.transaction.impl.xa
 
XATransactionDTO() - Constructor for class com.hazelcast.transaction.impl.xa.XATransactionDTO
 
XATransactionDTO(XATransaction) - Constructor for class com.hazelcast.transaction.impl.xa.XATransactionDTO
 
XATransactionDTO(UUID, SerializableXID, UUID, long, long, List<TransactionLogRecord>) - Constructor for class com.hazelcast.transaction.impl.xa.XATransactionDTO
 
XATransactionFinalizeCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
XATransactionFinalizeCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
XATransactionFinalizeCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
XATransactionPrepareCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
XATransactionPrepareCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
XATransactionPrepareCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
XATransactionPrepareMessageTask - Class in com.hazelcast.client.impl.protocol.task.transaction
 
XATransactionPrepareMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transaction.XATransactionPrepareMessageTask
 
XATransactionProxy - Class in com.hazelcast.client.impl.proxy.txn.xa
This class does not need to be thread-safe, it is only used via XAResource All visibility guarantees handled by XAResource
XATransactionProxy(HazelcastClientInstanceImpl, ClientConnection, Xid, int) - Constructor for class com.hazelcast.client.impl.proxy.txn.xa.XATransactionProxy
 
XATransactionRollbackCodec - Class in com.hazelcast.client.impl.protocol.codec
TODO DOC
XATransactionRollbackCodec.RequestParameters - Class in com.hazelcast.client.impl.protocol.codec
 
XATransactionRollbackCodec.ResponseParameters - Class in com.hazelcast.client.impl.protocol.codec
 
XATransactionRollbackMessageTask - Class in com.hazelcast.client.impl.protocol.task.transaction
 
XATransactionRollbackMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.transaction.XATransactionRollbackMessageTask
 
xid - Variable in class com.hazelcast.client.impl.protocol.codec.XATransactionClearRemoteCodec.RequestParameters
Java XA transaction id as defined in interface javax.transaction.xa.Xid.
xid - Variable in class com.hazelcast.client.impl.protocol.codec.XATransactionCreateCodec.RequestParameters
Java XA transaction id as defined in interface javax.transaction.xa.Xid.
xid - Variable in class com.hazelcast.client.impl.protocol.codec.XATransactionFinalizeCodec.RequestParameters
Java XA transaction id as defined in interface javax.transaction.xa.Xid.
XidCodec - Class in com.hazelcast.client.impl.protocol.codec.custom
 
XML_ACCEPTED_SUFFIXES - Static variable in class com.hazelcast.internal.config.DeclarativeConfigUtil
Array of accepted suffixes for XML configuration files.
XML_ACCEPTED_SUFFIXES_STRING - Static variable in class com.hazelcast.internal.config.DeclarativeConfigUtil
List of accepted suffixes for XML configuration files.
XmlClientConfigBuilder - Class in com.hazelcast.client.config
Loads the ClientConfig using XML.
XmlClientConfigBuilder(String) - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
 
XmlClientConfigBuilder(File) - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
 
XmlClientConfigBuilder(URL) - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
 
XmlClientConfigBuilder(InputStream) - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
 
XmlClientConfigBuilder() - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
Loads the client config using the following resolution mechanism: first it checks if a system property 'hazelcast.client.config' is set.
XmlClientConfigBuilder(XmlClientConfigLocator) - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
Constructs a XmlClientConfigBuilder that loads the configuration with the provided XmlClientConfigLocator.
XmlClientConfigLocator - Class in com.hazelcast.client.config
A support class for the XmlClientConfigBuilder to locate the client xml configuration.
XmlClientConfigLocator() - Constructor for class com.hazelcast.client.config.XmlClientConfigLocator
 
XmlClientFailoverConfigBuilder - Class in com.hazelcast.client.config
Loads the ClientFailoverConfig using XML.
XmlClientFailoverConfigBuilder(String) - Constructor for class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
 
XmlClientFailoverConfigBuilder(File) - Constructor for class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
 
XmlClientFailoverConfigBuilder(URL) - Constructor for class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
 
XmlClientFailoverConfigBuilder(InputStream) - Constructor for class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
 
XmlClientFailoverConfigBuilder() - Constructor for class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
Loads the client failover config using the following resolution mechanism: first it checks if a system property 'hazelcast.client.failover.config' is set.
XmlClientFailoverConfigBuilder(XmlClientFailoverConfigLocator) - Constructor for class com.hazelcast.client.config.XmlClientFailoverConfigBuilder
Constructs a XmlClientFailoverConfigBuilder that loads the configuration with the provided XmlClientFailoverConfigLocator.
XmlClientFailoverConfigLocator - Class in com.hazelcast.client.config
A support class for the XmlClientFailoverConfigBuilder to locate the client failover XML configuration.
XmlClientFailoverConfigLocator() - Constructor for class com.hazelcast.client.config.XmlClientFailoverConfigLocator
 
XmlConfigBuilder - Class in com.hazelcast.config
A XML ConfigBuilder implementation.
XmlConfigBuilder(String) - Constructor for class com.hazelcast.config.XmlConfigBuilder
Constructs a XmlConfigBuilder that reads from the provided XML file.
XmlConfigBuilder(InputStream) - Constructor for class com.hazelcast.config.XmlConfigBuilder
Constructs a XmlConfigBuilder that reads from the given InputStream.
XmlConfigBuilder(URL) - Constructor for class com.hazelcast.config.XmlConfigBuilder
Constructs a XMLConfigBuilder that reads from the given URL.
XmlConfigBuilder() - Constructor for class com.hazelcast.config.XmlConfigBuilder
Constructs a XmlConfigBuilder that tries to find a usable XML configuration file.
XmlConfigBuilder(XmlConfigLocator) - Constructor for class com.hazelcast.config.XmlConfigBuilder
Constructs a XmlConfigBuilder that loads the configuration with the provided XmlConfigLocator.
XmlConfigLocator - Class in com.hazelcast.config
Support class for the XmlConfigBuilder that locates the XML configuration: system property working directory classpath default
XmlConfigLocator() - Constructor for class com.hazelcast.config.XmlConfigLocator
 
XmlGenerator(StringBuilder) - Constructor for class com.hazelcast.config.ConfigXmlGenerator.XmlGenerator
 
xmlToJavaName(String) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 

Y

YAML_ACCEPTED_SUFFIXES - Static variable in class com.hazelcast.internal.config.DeclarativeConfigUtil
Array of accepted suffixes for YAML configuration files.
YAML_ACCEPTED_SUFFIXES_STRING - Static variable in class com.hazelcast.internal.config.DeclarativeConfigUtil
List of accepted suffixes for YAML configuration files.
YamlClientConfigBuilder - Class in com.hazelcast.client.config
Loads the ClientConfig using YAML.
YamlClientConfigBuilder(String) - Constructor for class com.hazelcast.client.config.YamlClientConfigBuilder
 
YamlClientConfigBuilder(File) - Constructor for class com.hazelcast.client.config.YamlClientConfigBuilder
 
YamlClientConfigBuilder(URL) - Constructor for class com.hazelcast.client.config.YamlClientConfigBuilder
 
YamlClientConfigBuilder(InputStream) - Constructor for class com.hazelcast.client.config.YamlClientConfigBuilder
 
YamlClientConfigBuilder() - Constructor for class com.hazelcast.client.config.YamlClientConfigBuilder
Loads the client config using the following resolution mechanism: first it checks if a system property 'hazelcast.client.config' is set.
YamlClientConfigBuilder(YamlClientConfigLocator) - Constructor for class com.hazelcast.client.config.YamlClientConfigBuilder
Constructs a YamlClientConfigBuilder that loads the configuration with the provided YamlClientConfigLocator.
YamlClientConfigLocator - Class in com.hazelcast.client.config
A support class for the YamlClientConfigBuilder to locate the client YAML configuration.
YamlClientConfigLocator() - Constructor for class com.hazelcast.client.config.YamlClientConfigLocator
 
YamlClientFailoverConfigBuilder - Class in com.hazelcast.client.config
Loads the ClientFailoverConfig using YAML.
YamlClientFailoverConfigBuilder(String) - Constructor for class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
 
YamlClientFailoverConfigBuilder(File) - Constructor for class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
 
YamlClientFailoverConfigBuilder(URL) - Constructor for class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
 
YamlClientFailoverConfigBuilder(InputStream) - Constructor for class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
 
YamlClientFailoverConfigBuilder() - Constructor for class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
Loads the client failover config using the following resolution mechanism: first it checks if a system property 'hazelcast.client.failover.config' is set.
YamlClientFailoverConfigBuilder(YamlClientFailoverConfigLocator) - Constructor for class com.hazelcast.client.config.YamlClientFailoverConfigBuilder
Constructs a YamlClientFailoverConfigBuilder that loads the configuration with the provided YamlClientFailoverConfigLocator.
YamlClientFailoverConfigLocator - Class in com.hazelcast.client.config
A support class for the YamlClientFailoverConfigBuilder to locate the client failover YAML configuration.
YamlClientFailoverConfigLocator() - Constructor for class com.hazelcast.client.config.YamlClientFailoverConfigLocator
 
YamlCollection - Interface in com.hazelcast.internal.yaml
Common ancestor interface for YamlMapping and YamlSequence nodes
YamlConfigBuilder - Class in com.hazelcast.config
A YAML ConfigBuilder implementation.
YamlConfigBuilder(String) - Constructor for class com.hazelcast.config.YamlConfigBuilder
Constructs a YamlConfigBuilder that reads from the provided YAML file.
YamlConfigBuilder(InputStream) - Constructor for class com.hazelcast.config.YamlConfigBuilder
Constructs a YAMLConfigBuilder that reads from the given InputStream.
YamlConfigBuilder(URL) - Constructor for class com.hazelcast.config.YamlConfigBuilder
Constructs a YamlConfigBuilder that reads from the given URL.
YamlConfigBuilder() - Constructor for class com.hazelcast.config.YamlConfigBuilder
Constructs a YamlConfigBuilder that tries to find a usable YAML configuration file.
YamlConfigBuilder(YamlConfigLocator) - Constructor for class com.hazelcast.config.YamlConfigBuilder
Constructs a YamlConfigBuilder that loads the configuration with the provided YamlConfigLocator.
YamlConfigLocator - Class in com.hazelcast.config
Support class for the YamlConfigBuilder that locates the YAML configuration: system property working directory classpath default
YamlConfigLocator() - Constructor for class com.hazelcast.config.YamlConfigLocator
 
YamlDomBuilder - Class in com.hazelcast.internal.yaml
Builds a DOM of YamlNode instances from the structure parsed by SnakeYaml.
YamlDomChecker - Class in com.hazelcast.internal.config.yaml
Utility class for checking the provided YAML DOM for null scalar values and mappings or sequences with null child nodes.
YamlException - Exception in com.hazelcast.internal.yaml
 
YamlException(String) - Constructor for exception com.hazelcast.internal.yaml.YamlException
 
YamlException(String, Throwable) - Constructor for exception com.hazelcast.internal.yaml.YamlException
 
YamlLoader - Class in com.hazelcast.internal.yaml
YAML loader that can load, parse YAML documents and can build a tree of YamlNode instances.
YamlMapping - Interface in com.hazelcast.internal.yaml
Interface for YAML mapping nodes
YamlMappingImpl - Class in com.hazelcast.internal.yaml
 
YamlNameNodePair - Class in com.hazelcast.internal.yaml
A pair consists of a node's name and its representing YamlNode instance
YamlNode - Interface in com.hazelcast.internal.yaml
Generic YAML node interface
YamlScalar - Interface in com.hazelcast.internal.yaml
Interface for YAML scalar nodes
YamlScalarImpl - Class in com.hazelcast.internal.yaml
 
YamlScalarImpl(YamlNode, String, Object) - Constructor for class com.hazelcast.internal.yaml.YamlScalarImpl
 
YamlSequence - Interface in com.hazelcast.internal.yaml
Interface for YAML sequence nodes
YamlUtil - Class in com.hazelcast.internal.yaml
Utility class for working with YAML nodes.

Z

zeroOutMs(long) - Static method in class com.hazelcast.internal.util.TimeUtil
Cleans the milliseconds info from the timestamp
ZoneAwareMemberGroupFactory - Class in com.hazelcast.partition.membergroup
ZoneAwareMemberGroupFactory is responsible for MemberGroups creation according to the host metadata provided by DiscoveryStrategy.discoverLocalMetadata()
ZoneAwareMemberGroupFactory() - Constructor for class com.hazelcast.partition.membergroup.ZoneAwareMemberGroupFactory
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 
Skip navigation links

Copyright © 2019 Hazelcast, Inc.. All rights reserved.