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 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
 
AbstractAlterOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AbstractAlterOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
 
AbstractAlterOperation(String, IFunction<Long, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
 
AbstractAlterOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
AbstractAlterOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
 
AbstractAlterOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
 
AbstractAtomicLongOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AbstractAtomicLongOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AbstractAtomicLongOperation
 
AbstractAtomicLongOperation(String) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AbstractAtomicLongOperation
 
AbstractAtomicReferenceOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
AbstractAtomicReferenceOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AbstractAtomicReferenceOperation
 
AbstractAtomicReferenceOperation(String) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AbstractAtomicReferenceOperation
 
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(String, 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
 
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
 
AbstractCacheOperation - Class in com.hazelcast.cache.impl.operation
Base Cache Operation.
AbstractCacheOperation() - Constructor for class com.hazelcast.cache.impl.operation.AbstractCacheOperation
 
AbstractCacheOperation(String, Data) - Constructor for class com.hazelcast.cache.impl.operation.AbstractCacheOperation
 
AbstractCacheRecord<V> - Class in com.hazelcast.cache.impl.record
Abstract implementation of CacheRecord with key, value and expiration time as internal state.
AbstractCacheRecord() - Constructor for class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
AbstractCacheRecord(long, long) - Constructor for class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
AbstractCacheRecordStore<R extends CacheRecord,CRM extends SampleableCacheRecordMap<Data,R>> - Class in com.hazelcast.cache.impl
 
AbstractCacheRecordStore(String, int, NodeEngine, AbstractCacheService) - Constructor for class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
AbstractCacheService - Class in com.hazelcast.cache.impl
 
AbstractCacheService() - Constructor for class com.hazelcast.cache.impl.AbstractCacheService
 
AbstractCallableMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
Base callable Message task.
AbstractCallableMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractCallableMessageTask
 
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) - 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
 
AbstractClientInvocationService - Class in com.hazelcast.client.spi.impl
 
AbstractClientInvocationService(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.spi.impl.AbstractClientInvocationService
 
AbstractClientListenerService - Class in com.hazelcast.client.spi.impl.listener
 
AbstractClientListenerService(HazelcastClientInstanceImpl, int, int) - Constructor for class com.hazelcast.client.spi.impl.listener.AbstractClientListenerService
 
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
 
AbstractCompletableFuture<V> - Class in com.hazelcast.spi.impl
A base ICompletableFuture implementation that may be explicitly completed by setting its value through setResult.
AbstractCompletableFuture(NodeEngine, ILogger) - Constructor for class com.hazelcast.spi.impl.AbstractCompletableFuture
 
AbstractCompletableFuture(Executor, ILogger) - Constructor for class com.hazelcast.spi.impl.AbstractCompletableFuture
 
AbstractConfigBuilder - Class in com.hazelcast.config
Contains logic for replacing system variables in the XML file and importing XML files from different locations.
AbstractConfigBuilder() - Constructor for class com.hazelcast.config.AbstractConfigBuilder
 
AbstractConfigBuilder.ConfigType - Enum in com.hazelcast.config
 
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
 
AbstractCRDTReplicationOperation<T extends IdentifiedDataSerializable> - Class in com.hazelcast.crdt
Base class for CRDT replication operations.
AbstractCRDTReplicationOperation() - Constructor for class com.hazelcast.crdt.AbstractCRDTReplicationOperation
 
AbstractCRDTReplicationOperation(Map<String, T>) - Constructor for class com.hazelcast.crdt.AbstractCRDTReplicationOperation
Constructs the replication operation.
AbstractCredentials - Class in com.hazelcast.security
Abstract implementation of Credentials
AbstractCredentials() - Constructor for class com.hazelcast.security.AbstractCredentials
 
AbstractCredentials(String) - Constructor for class com.hazelcast.security.AbstractCredentials
 
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
Abstract DistributedObject implementation.
AbstractDistributedObject(NodeEngine, S) - Constructor for class com.hazelcast.spi.AbstractDistributedObject
 
AbstractDynamicConfigOperation - Class in com.hazelcast.internal.dynamicconfig
 
AbstractDynamicConfigOperation() - Constructor for class com.hazelcast.internal.dynamicconfig.AbstractDynamicConfigOperation
 
AbstractEntryProcessor<K,V> - Class in com.hazelcast.map
An abstract EntryProcessor that already has implemented the AbstractEntryProcessor.getBackupProcessor().
AbstractEntryProcessor() - Constructor for class com.hazelcast.map.AbstractEntryProcessor
Creates an AbstractEntryProcessor that applies the EntryProcessor.process(java.util.Map.Entry) to primary and backups.
AbstractEntryProcessor(boolean) - Constructor for class com.hazelcast.map.AbstractEntryProcessor
Creates an AbstractEntryProcessor.
AbstractExecutorServiceCancelMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.executorservice
 
AbstractExecutorServiceCancelMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.AbstractExecutorServiceCancelMessageTask
 
AbstractExecutorThreadFactory - Class in com.hazelcast.util.executor
 
AbstractExecutorThreadFactory(ClassLoader) - Constructor for class com.hazelcast.util.executor.AbstractExecutorThreadFactory
 
AbstractFilteringStrategy - Class in com.hazelcast.map.impl.event
A common abstract class to support implementations of filtering strategies.
AbstractFilteringStrategy(SerializationService, 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 CacheManager as indirect) implementation provides shared functionality to server and client cache managers.
AbstractHazelcastCacheManager(CachingProvider, HazelcastInstance, URI, ClassLoader, Properties) - Constructor for class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
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.core
The abstract class for a map event IMapEvent.
AbstractIMapEvent(Object, Member, int) - Constructor for class com.hazelcast.core.AbstractIMapEvent
Constructs a prototypical map Event.
AbstractIndexAwarePredicate<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(Executor, ILogger) - Constructor for class com.hazelcast.spi.impl.AbstractInvocationFuture
 
AbstractInvocationMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
 
AbstractInvocationMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractInvocationMessageTask
 
AbstractJob<KeyIn,ValueIn> - Class in com.hazelcast.mapreduce.impl
Base class for all map reduce job implementations
AbstractJob(String, JobTracker, KeyValueSource<KeyIn, ValueIn>) - Constructor for class com.hazelcast.mapreduce.impl.AbstractJob
 
AbstractJob.MappingJobImpl<EntryKey,Key,Value> - Class in com.hazelcast.mapreduce.impl
This class is just used to comply to the public DSL style API
AbstractJob.ReducingJobImpl<EntryKey,Key,Value> - Class in com.hazelcast.mapreduce.impl
This class is just used to comply to the public DSL style API
AbstractJob.ReducingSubmittableJobImpl<EntryKey,Key,Value> - Class in com.hazelcast.mapreduce.impl
This class is just used to comply to the public DSL style API
AbstractJobTracker - Class in com.hazelcast.mapreduce.impl
This is the base class for all JobTracker implementations on node and client side.
It combines a lot of the base functionality to handle remote operations.
AbstractJoiner - Class in com.hazelcast.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
 
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
Abstract class for local operations, which should not be serializable.
AbstractLocalOperation() - Constructor for class com.hazelcast.spi.AbstractLocalOperation
 
AbstractLockOperation - Class in com.hazelcast.concurrent.lock.operations
 
AbstractLockOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
AbstractLockOperation(ObjectNamespace, Data, long) - Constructor for class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
AbstractLockOperation(ObjectNamespace, Data, long, long) - Constructor for class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
AbstractLockOperation(ObjectNamespace, Data, long, long, long) - Constructor for class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
AbstractLogger - Class in com.hazelcast.logging
Abstract ILogger implementation that provides implementations for the convenience methods like finest,info,warning and severe.
AbstractLogger() - Constructor for class com.hazelcast.logging.AbstractLogger
 
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(MapStoreWrapper, InternalSerializationService) - 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
 
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<Map.Entry<K, V>, R>) - Constructor for class com.hazelcast.map.impl.iterator.AbstractMapQueryPartitionIterator
 
AbstractMapReduceTask<Parameters> - Class in com.hazelcast.client.impl.protocol.task.mapreduce
 
AbstractMapReduceTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.mapreduce.AbstractMapReduceTask
 
AbstractMember - Class in com.hazelcast.instance
 
AbstractMember() - Constructor for class com.hazelcast.instance.AbstractMember
 
AbstractMember(Address, MemberVersion, String, Map<String, Object>, boolean) - Constructor for class com.hazelcast.instance.AbstractMember
 
AbstractMember(AbstractMember) - Constructor for class com.hazelcast.instance.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
 
AbstractMutatingCacheOperation - Class in com.hazelcast.cache.impl.operation
Base class for all mutable cache operations.
AbstractMutatingCacheOperation() - Constructor for class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
 
AbstractMutatingCacheOperation(String, Data, int) - Constructor for class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
 
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
 
AbstractNamedOperation(String) - Constructor for class com.hazelcast.spi.impl.AbstractNamedOperation
 
AbstractNamedOperation() - Constructor for class com.hazelcast.spi.impl.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
 
AbstractPingAwareQuorumFunction - Class in com.hazelcast.quorum.impl
Base class for quorum functions which may use ICMP failure detector information to determine presence of quorum.
AbstractPingAwareQuorumFunction() - Constructor for class com.hazelcast.quorum.impl.AbstractPingAwareQuorumFunction
 
AbstractPNCounterOperation - Class in com.hazelcast.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
 
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
 
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
 
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
 
AbstractStableClusterMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
 
AbstractStableClusterMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractStableClusterMessageTask
 
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
 
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
 
AbstractVisitor - Class in com.hazelcast.query.impl.predicates
Base class for all visitors.
AbstractVisitor() - Constructor for class com.hazelcast.query.impl.predicates.AbstractVisitor
 
AbstractWaitNotifyKey - Class in com.hazelcast.spi
Abstract implementation of the WaitNotifyKey.
AbstractWaitNotifyKey(String, String) - Constructor for class com.hazelcast.spi.AbstractWaitNotifyKey
 
AbstractXAOperation - Class in com.hazelcast.transaction.impl.xa.operations
 
AbstractXAOperation() - Constructor for class com.hazelcast.transaction.impl.xa.operations.AbstractXAOperation
 
AbstractXmlConfigHelper - Class in com.hazelcast.config
Contains Hazelcast XML Configuration helper methods and variables.
AbstractXmlConfigHelper() - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper
 
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(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(Visitor, Indexes) - Method in class com.hazelcast.query.impl.predicates.AndPredicate
 
accept(Visitor, Indexes) - Method in class com.hazelcast.query.impl.predicates.NotPredicate
 
accept(Visitor, Indexes) - Method in class com.hazelcast.query.impl.predicates.OrPredicate
 
accept(Visitor, Indexes) - Method in class com.hazelcast.query.SqlPredicate
 
accept(Visitor, Indexes) - Method in interface com.hazelcast.query.VisitablePredicate
Accept visitor.
accept(int, int, V) - Method in interface com.hazelcast.util.collection.BiInt2ObjectMap.EntryConsumer
A map entry
accept(T, U) - Method in interface com.hazelcast.util.function.BiConsumer
Performs this operation on the given arguments.
accept(T) - Method in interface com.hazelcast.util.function.Consumer
Performs this operation on the given argument.
accept(long, long) - Method in interface com.hazelcast.util.function.LongLongConsumer
Accept a key and value that comes as a tuple of longs.
ACCEPT_ALL_SUPPLIER - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
AcceptAllSupplier<KeyIn,ValueIn,ValueOut> - Class in com.hazelcast.mapreduce.aggregation.impl
A standard implementation of the Supplier interface which accepts all input values and may apply a given PropertyExtractor on those.
AcceptAllSupplier(PropertyExtractor<ValueIn, ValueOut>) - Constructor for class com.hazelcast.mapreduce.aggregation.impl.AcceptAllSupplier
 
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
 
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, Double) - Method in class com.hazelcast.aggregation.impl.DoubleAverageAggregator
 
accumulateExtracted(I, Double) - 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, Integer) - Method in class com.hazelcast.aggregation.impl.IntegerAverageAggregator
 
accumulateExtracted(I, Integer) - Method in class com.hazelcast.aggregation.impl.IntegerSumAggregator
 
accumulateExtracted(I, Long) - Method in class com.hazelcast.aggregation.impl.LongAverageAggregator
 
accumulateExtracted(I, Long) - 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
 
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
 
AccumulatorConsumerOperation - Class in com.hazelcast.map.impl.operation
Processes remaining items in Accumulator instances on a partition.
AccumulatorConsumerOperation() - Constructor for class com.hazelcast.map.impl.operation.AccumulatorConsumerOperation
 
AccumulatorConsumerOperation(Queue<Accumulator>, int) - Constructor for class com.hazelcast.map.impl.operation.AccumulatorConsumerOperation
 
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.proxy.ClientSemaphoreProxy
 
acquire(int) - Method in class com.hazelcast.client.proxy.ClientSemaphoreProxy
 
acquire(String, int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
 
acquire() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
acquire(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
acquire() - Method in interface com.hazelcast.core.ISemaphore
Acquires a permit if one is available, and returns immediately, reducing the number of available permits by one.
acquire(int) - Method in interface com.hazelcast.core.ISemaphore
Acquires the given number of permits if they are available, and returns immediately, reducing the number of available permits by the given amount.
ACQUIRE_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
ACQUIRE_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
AcquireBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
AcquireBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireBackupOperation
 
AcquireBackupOperation(String, int, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireBackupOperation
 
AcquireOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
AcquireOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
 
AcquireOperation(String, int, long) - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
 
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.
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(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(Object) - Method in class com.hazelcast.client.proxy.ClientCardinalityEstimatorProxy
 
add(int, E) - Method in class com.hazelcast.client.proxy.ClientListProxy
 
add(E) - Method in class com.hazelcast.client.proxy.ClientListProxy
 
add(E) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
 
add(E) - Method in class com.hazelcast.client.proxy.ClientRingbufferProxy
 
add(E) - Method in class com.hazelcast.client.proxy.ClientSetProxy
 
add(E) - Method in class com.hazelcast.client.proxy.txn.ClientTxnListProxy
 
add(E) - Method in class com.hazelcast.client.proxy.txn.ClientTxnSetProxy
 
add(E) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
add(Data) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
add(int, Data) - Method in class com.hazelcast.collection.impl.list.ListContainer
 
add(int, E) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
 
add(E) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
 
add(E) - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
 
add(E) - Method in class com.hazelcast.collection.impl.txnset.TransactionalSetProxy
 
add(CountDownLatchContainer) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
add(E) - Method in interface com.hazelcast.core.TransactionalList
Adds a new item to the transactional list.
add(E) - Method in interface com.hazelcast.core.TransactionalSet
Add new item to transactional set.
add(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(T) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.InvalidationQueue
 
add(long) - Method in interface com.hazelcast.internal.util.collection.LongSet
 
add(long) - Method in class com.hazelcast.internal.util.collection.LongSetHsa
 
add(Data, Data) - Method in class com.hazelcast.map.impl.MapEntries
 
add(K, V, long) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
 
add(Data, Object, long) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
add(DelayedEntry<Data, Object>) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
add(Data, Object, long) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
add(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(Address, long) - Method in class com.hazelcast.spi.CallsPerMember
 
add(Object, boolean) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.DefaultOperationQueue
 
add(Object, boolean) - Method in interface com.hazelcast.spi.impl.operationexecutor.impl.OperationQueue
Adds an task to this queue.
add(Address, long) - Method in interface com.hazelcast.spi.LiveOperations
Registers an invocation with this object.
add(Object) - Method in class com.hazelcast.spi.merge.RingbufferMergeData
Adds an item to the tail of the ringbuffer.
add(TransactionLogRecord) - Method in interface com.hazelcast.transaction.impl.Transaction
 
add(TransactionLogRecord) - Method in class com.hazelcast.transaction.impl.TransactionImpl
 
add(TransactionLogRecord) - Method in class com.hazelcast.transaction.impl.TransactionLog
 
add(TransactionLogRecord) - Method in class com.hazelcast.transaction.impl.xa.XATransaction
 
add(T) - Method in class com.hazelcast.util.collection.InflatableSet
 
add(T) - Method in class com.hazelcast.util.collection.InflatableSet.Builder
 
add(Integer) - Method in class com.hazelcast.util.collection.IntHashSet
 
add(int) - Method in class com.hazelcast.util.collection.IntHashSet
Primitive specialised overload of {this#add(Integer)}
add(Long) - Method in class com.hazelcast.util.collection.LongHashSet
add(long) - Method in class com.hazelcast.util.collection.LongHashSet
Primitive specialised overload of {this#add(Long)}
add(T, long) - Method in class com.hazelcast.util.ItemCounter
Add delta to the item
add(E) - Method in class com.hazelcast.util.UnmodifiableListIterator
 
ADD_ALL - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
ADD_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
ADD_ALL_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
 
ADD_ALL_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
ADD_ALL_BACKUP_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
 
ADD_ALL_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
 
ADD_AND_GET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
ADD_BACKUP - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
ADD_BACKUP_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
 
ADD_CACHE_CONFIG_OPERATION - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
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_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
ADD_INTERCEPTOR - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
ADD_INTERCEPTOR_FACTORY - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
ADD_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
 
ADD_WAN_CONFIG - Static variable in class com.hazelcast.internal.management.ManagementDataSerializerHook
 
addAction(String) - Method in class com.hazelcast.config.PermissionConfig
 
addAddress(String...) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated.
addAddress(String...) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Adds given addresses to candidate address list that client will use to establish initial connection
addAll(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(int, Collection<? extends E>) - Method in class com.hazelcast.client.proxy.ClientListProxy
 
addAll(Collection<? extends E>) - Method in class com.hazelcast.client.proxy.ClientListProxy
 
addAll(Collection<? extends E>) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
 
addAll(Collection<? extends E>) - Method in class com.hazelcast.client.proxy.ClientSetProxy
 
addAll(Collection<? extends 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(T[]) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
Adds all items to the ring buffer.
addAll(Collection<? extends Integer>) - Method in class com.hazelcast.util.collection.IntHashSet
 
addAll(Collection<? extends Long>) - Method in class com.hazelcast.util.collection.LongHashSet
addAllAsync(Collection<? extends E>, OverflowPolicy) - Method in class com.hazelcast.client.proxy.ClientRingbufferProxy
 
addAllAsync(Collection<? extends E>, OverflowPolicy) - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
 
addAllAsync(Collection<? extends E>, OverflowPolicy) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Adds all the items of a collection to the tail of the Ringbuffer.
addAllBackup(Map<Long, Data>) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
addAllBackup(Map<Long, Data>) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
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.proxy.ClientAtomicLongProxy
 
addAndGet(long) - Method in class com.hazelcast.client.proxy.ClientPNCounterProxy
 
addAndGet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
 
addAndGet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
addAndGet(long) - Method in interface com.hazelcast.core.IAtomicLong
Atomically adds the given value to the current value.
addAndGet(long) - Method in interface com.hazelcast.crdt.pncounter.PNCounter
Adds the given value to the current value.
addAndGet(long, VectorClock) - Method in class com.hazelcast.crdt.pncounter.PNCounterImpl
Adds the given value to the current value.
addAndGet(long) - Method in class com.hazelcast.crdt.pncounter.PNCounterProxy
 
addAndGet(long) - Method in class com.hazelcast.internal.jmx.AtomicLongMBean
 
addAndGetAsync(long) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
 
addAndGetAsync(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
addAndGetAsync(long) - Method in interface com.hazelcast.core.IAtomicLong
Atomically adds the given value to the current value.
addAndGetMissedSequenceCount(long) - Method in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataContainer
 
AddAndGetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AddAndGetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
 
AddAndGetOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
 
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.proxy.ClientCardinalityEstimatorProxy
 
addAsync(E, OverflowPolicy) - Method in class com.hazelcast.client.proxy.ClientRingbufferProxy
 
addAsync(E, OverflowPolicy) - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
 
addAsync(E, OverflowPolicy) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
Asynchronously writes an item with a configurable OverflowPolicy.
addAtomicLongConfig(AtomicLongConfig) - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
 
addAtomicLongConfig(AtomicLongConfig) - Method in class com.hazelcast.config.Config
Adds the AtomicLong configuration.
addAtomicLongConfig(AtomicLongConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
addAtomicReferenceConfig(AtomicReferenceConfig) - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
 
addAtomicReferenceConfig(AtomicReferenceConfig) - Method in class com.hazelcast.config.Config
Adds the AtomicReference configuration.
addAtomicReferenceConfig(AtomicReferenceConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
addAwait(Data, String, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
addBackup(long, Data) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
 
addBackup(K, V, long) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
 
addBackup(Data, Object, long) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
addBackup(Data, Object, long) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
AddBackupOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AddBackupOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
 
AddBackupOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
 
AddBackupOperation - Class in com.hazelcast.ringbuffer.impl.operations
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.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 class com.hazelcast.config.CacheConfigReadOnly
Deprecated.
 
addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in interface com.hazelcast.config.CacheConfiguration
Add a configuration for a CacheEntryListener.
addCachePartitionLostListenerConfig(CachePartitionLostListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
Adds the CachePartitionLostListenerConfig to partitionLostListenerConfigs.
addCachePartitionLostListenerConfig(CachePartitionLostListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
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.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
 
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
 
addClientListener(ClientListener) - Method in class com.hazelcast.client.impl.ClientServiceProxy
 
addClientListener(ClientListener) - Method in interface com.hazelcast.core.ClientService
Adds a ClientListener.
addClientLoginModuleConfig(LoginModuleConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addClientLoginModuleConfig(LoginModuleConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
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.
addConnectionHeartbeatListener(ConnectionHeartbeatListener) - Method in interface com.hazelcast.client.connection.ClientConnectionManager
 
addConnectionHeartbeatListener(ConnectionHeartbeatListener) - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
 
addConnectionHeartbeatListener(ConnectionHeartbeatListener) - Method in class com.hazelcast.client.connection.nio.HeartbeatManager
 
addConnectionListener(ConnectionListener) - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
 
addConnectionListener(ConnectionListener) - Method in interface com.hazelcast.nio.ConnectionListenable
Registers a ConnectionListener.
addConnectionListener(ConnectionListener) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
 
addContainer(String, CollectionContainer) - Method in class com.hazelcast.collection.impl.collection.CollectionService
 
addContainer(String, QueueContainer) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
addCountDownLatchConfig(CountDownLatchConfig) - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
 
addCountDownLatchConfig(CountDownLatchConfig) - Method in class com.hazelcast.config.Config
Adds the CountDownLatch configuration.
addCountDownLatchConfig(CountDownLatchConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
addDataSerializableFactory(int, DataSerializableFactory) - Method in class com.hazelcast.config.SerializationConfig
 
addDataSerializableFactory(int, DataSerializableFactory) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
addDataSerializableFactory(int, DataSerializableFactory) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
addDataSerializableFactoryClass(int, String) - Method in class com.hazelcast.config.SerializationConfig
 
addDataSerializableFactoryClass(int, Class<? extends DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
 
addDestroyAction(String, Callable<Boolean>) - Method in interface com.hazelcast.client.ClientEndpoint
Adds a remove callable to be called when endpoint is destroyed Note: removeDestroyAction should be called when there is no need to destroy action anymore.
addDestroyAction(String, Callable<Boolean>) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
addDiscoveryStrategyConfig(DiscoveryStrategyConfig) - Method in class com.hazelcast.config.DiscoveryConfig
Adds an enabled DiscoveryStrategy configuration.
addDiscoveryStrategyConfig(DiscoveryStrategyConfig) - Method in class com.hazelcast.config.DiscoveryConfigReadOnly
Deprecated.
 
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
 
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
 
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.client.spi.ProxyManager
 
addDistributedObjectListener(DistributedObjectListener) - Method in interface com.hazelcast.core.HazelcastInstance
Adds a Distributed Object listener which will be notified when a new DistributedObject will be created or destroyed.
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
AddDistributedObjectListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task
 
AddDistributedObjectListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
 
addDoubleArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addDoubleField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addDurableExecutorConfig(DurableExecutorConfig) - Method in class com.hazelcast.client.impl.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.
addEndpoint(String) - Method in class com.hazelcast.config.PermissionConfig
 
addEntryListener(MapListener, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addEntryListener(EntryListener, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addEntryListener(MapListener, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addEntryListener(EntryListener, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addEntryListener(EntryListener<K, V>, boolean) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
 
addEntryListener(EntryListener<K, V>, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
 
addEntryListener(EntryListener<K, V>) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
 
addEntryListener(EntryListener<K, V>, K) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
 
addEntryListener(EntryListener<K, V>, Predicate<K, V>) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
 
addEntryListener(EntryListener<K, V>, Predicate<K, V>, K) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
 
addEntryListener(MapListener, boolean) - Method in interface com.hazelcast.core.IMap
Adds a MapListener for this map.
addEntryListener(EntryListener, boolean) - Method in interface com.hazelcast.core.IMap
Deprecated.
addEntryListener(MapListener, K, boolean) - Method in interface com.hazelcast.core.IMap
Adds a MapListener for this map.
addEntryListener(EntryListener, K, boolean) - Method in interface com.hazelcast.core.IMap
addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
Adds a MapListener for this map.
addEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
Adds a MapListener for this map.
addEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
addEntryListener(EntryListener<K, V>, boolean) - Method in interface com.hazelcast.core.MultiMap
Adds an entry listener for this multimap.
addEntryListener(EntryListener<K, V>, K, boolean) - Method in interface com.hazelcast.core.MultiMap
Adds the specified entry listener for the specified key.
addEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.core.ReplicatedMap
Adds an entry listener for this map.
addEntryListener(EntryListener<K, V>, K) - Method in interface com.hazelcast.core.ReplicatedMap
Adds the specified entry listener for the specified key.
addEntryListener(EntryListener<K, V>, Predicate<K, V>) - Method in interface com.hazelcast.core.ReplicatedMap
Adds an continuous entry listener for this map.
addEntryListener(EntryListener<K, V>, Predicate<K, V>, K) - Method in interface com.hazelcast.core.ReplicatedMap
Adds an continuous entry listener for this map.
addEntryListener(MapListener, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addEntryListener(EntryListener, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addEntryListener(MapListener, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addEntryListener(EntryListener, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addEntryListener(MapListener, boolean) - Method in 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>) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
addEntryListener(EntryListener<K, V>, K) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
addEntryListener(EntryListener<K, V>, Predicate<K, V>) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
addEntryListener(EntryListener<K, V>, Predicate<K, V>, K) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
addEntryListenerConfig(CacheSimpleEntryListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
addEntryListenerConfig(CacheSimpleEntryListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
Deprecated.
 
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MapConfig
 
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MultiMapConfig
Adds an entry listener to this MultiMap (listens for when entries are added or removed).
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
Deprecated.
 
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.QueryCacheConfig
Adds EntryListenerConfig to this QueryCacheConfig.
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.ReplicatedMapConfig
 
addEventData(CacheEventData) - Method in class com.hazelcast.cache.impl.CacheEventSet
Helper method for adding multiple CacheEventData into this Set
addEventHandler(long, EventHandler) - Method in class com.hazelcast.client.spi.impl.listener.AbstractClientListenerService
 
addEventJournalConfig(EventJournalConfig) - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
 
addEventJournalConfig(EventJournalConfig) - Method in class com.hazelcast.config.Config
Adds the event journal configuration.
addEventJournalConfig(EventJournalConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
AddEventJournalConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
AddEventJournalConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddEventJournalConfigMessageTask
 
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.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
Add class name implementing the CacheWanEventFilter or MapWanEventFilter for filtering WAN replication events.
addFilter(String) - Method in class com.hazelcast.config.WanReplicationRefReadOnly
Deprecated.
 
addFirst(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
Inserts collection of elements to the front of this queue.
addFlag(short) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
Sets the flags field value.
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.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
 
addGetTimeNanos(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Increments the getCache time accumulator.
addIndex(String, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addIndex(String, boolean) - Method in interface com.hazelcast.core.IMap
Adds an index to this map for the specified entries so that queries can run faster.
addIndex(String, boolean) - Method in class com.hazelcast.map.impl.querycache.subscriber.NullQueryCache
 
addIndex(String, boolean) - Method in interface com.hazelcast.map.QueryCache
 
addIndexConfig(MapIndexConfig) - Method in class com.hazelcast.config.QueryCacheConfig
 
addIndexInfo(String, boolean) - Method in class com.hazelcast.query.impl.MapIndexInfo
 
addIndexInfos(Collection<IndexInfo>) - Method in class com.hazelcast.query.impl.MapIndexInfo
 
AddIndexOperation - Class in com.hazelcast.map.impl.operation
 
AddIndexOperation() - Constructor for class com.hazelcast.map.impl.operation.AddIndexOperation
 
AddIndexOperation(String, String, boolean) - Constructor for class com.hazelcast.map.impl.operation.AddIndexOperation
 
AddIndexOperationFactory - Class in com.hazelcast.map.impl.operation
 
AddIndexOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.AddIndexOperationFactory
 
AddIndexOperationFactory(String, String, boolean) - Constructor for class com.hazelcast.map.impl.operation.AddIndexOperationFactory
 
addIntArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addInterceptor(MapInterceptor) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addInterceptor(MapInterceptor) - Method in interface com.hazelcast.core.IMap
Adds an interceptor for this map.
addInterceptor(String, String, MapInterceptor) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
 
addInterceptor(MapInterceptor) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
AddInterceptorOperation - Class in com.hazelcast.map.impl.operation
 
AddInterceptorOperation() - Constructor for class com.hazelcast.map.impl.operation.AddInterceptorOperation
 
AddInterceptorOperation(String, MapInterceptor, String) - Constructor for class com.hazelcast.map.impl.operation.AddInterceptorOperation
 
AddInterceptorOperationSupplier - Class in com.hazelcast.client.impl
 
AddInterceptorOperationSupplier(String, String, MapInterceptor) - Constructor for class com.hazelcast.client.impl.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.proxy.ClientListProxy
 
addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
 
addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.client.proxy.ClientSetProxy
 
addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
 
addItemListener(String, ItemListener, boolean, boolean) - Method in class com.hazelcast.collection.impl.queue.QueueService
 
addItemListener(ItemListener<E>, boolean) - Method in interface com.hazelcast.core.ICollection
Adds an item listener for this collection.
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.CollectionConfig
Adds an item listener to this collection (listens for when items are added or removed).
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.ListConfigReadOnly
Deprecated.
 
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.QueueConfig
Add an item listener configuration to this queue.
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.QueueConfigReadOnly
Deprecated.
 
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.SetConfigReadOnly
Deprecated.
 
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
 
addJobTrackerConfig(JobTrackerConfig) - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
 
addJobTrackerConfig(JobTrackerConfig) - Method in class com.hazelcast.config.Config
Adds the JobTracker configuration.
addJobTrackerConfig(JobTrackerConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
addLast(E) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
Inserts to the end of this queue.
addLifecycleListener(LifecycleListener) - Method in class com.hazelcast.client.impl.LifecycleServiceImpl
 
addLifecycleListener(LifecycleListener) - Method in interface com.hazelcast.core.LifecycleService
Add a listener object to listen for lifecycle events.
addLifecycleListener(LifecycleListener) - Method in class com.hazelcast.instance.LifecycleServiceImpl
 
addLifecycleListener(LifecycleListener) - Method in class com.hazelcast.instance.TerminatedLifecycleService
 
addListConfig(ListConfig) - Method in class com.hazelcast.client.impl.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.ClientDynamicClusterConfig
 
addListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.Config
Adds a configuration for an EventListener.
addListenerConfig(QuorumListenerConfig) - Method in class com.hazelcast.config.QuorumConfig
 
addListenerConfig(ListenerConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
addListenerDestroyAction(String, String, String) - Method in interface com.hazelcast.client.ClientEndpoint
Adds a remove callable to be called when endpoint is destroyed to clean related listener Following line will be called when endpoint destroyed : eventService.deregisterListener(service, topic, ID); Note: removeDestroyAction should be called when there is no need to destroy action anymore.
addListenerDestroyAction(String, String, String) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
addLocalEntryListener(MapListener) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addLocalEntryListener(EntryListener) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addLocalEntryListener(MapListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addLocalEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addLocalEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addLocalEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addLocalEntryListener(EntryListener<K, V>) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
 
addLocalEntryListener(MapListener) - Method in interface com.hazelcast.core.IMap
Adds a MapListener for this map.
addLocalEntryListener(EntryListener) - Method in interface com.hazelcast.core.IMap
Deprecated.
addLocalEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
Adds a MapListener for this map.
addLocalEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
addLocalEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
Adds a local entry listener for this map.
addLocalEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
addLocalEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.core.MultiMap
Adds a local entry listener for this multimap.
addLocalEntryListener(MapListener) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addLocalEntryListener(EntryListener) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addLocalEntryListener(MapListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addLocalEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addLocalEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addLocalEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addLocalEntryListener(EntryListener<K, V>) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
addLocalEventListener(Object, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
 
addLocalEventListener(Object, EventFilter, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
 
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(LockConfig) - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
 
addLockConfig(LockConfig) - Method in class com.hazelcast.config.Config
Adds the lock configuration.
addLockConfig(LockConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
AddLockConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
AddLockConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddLockConfigMessageTask
 
addLogListener(Level, LogListener) - Method in class com.hazelcast.client.impl.ClientLoggingService
 
addLogListener(Level, LogListener) - Method in interface com.hazelcast.logging.LoggingService
 
addLogListener(Level, LogListener) - Method in class com.hazelcast.logging.LoggingServiceImpl
 
addLongArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addLongField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addMapAttributeConfig(MapAttributeConfig) - Method in class com.hazelcast.config.MapConfig
 
addMapConfig(MapConfig) - Method in class com.hazelcast.client.impl.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
 
addMapIndex(MapServiceContext, MapContainer) - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
 
addMapIndexConfig(MapIndexConfig) - Method in class com.hazelcast.config.MapConfig
 
addMapIndexConfig(MapIndexConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
Deprecated.
 
addMapInterceptors(MapContainer) - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
 
addMapPartitionLostListenerConfig(MapPartitionLostListenerConfig) - Method in class com.hazelcast.config.MapConfig
 
addMember(String) - Method in class com.hazelcast.config.TcpIpConfig
Adds a 'well known' member.
addMember(Member) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
addMember(Member) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
addMember(Member) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
addMemberGroupConfig(MemberGroupConfig) - Method in class com.hazelcast.config.PartitionGroupConfig
addMemberLoginModuleConfig(LoginModuleConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addMemberLoginModuleConfig(LoginModuleConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicSecurityConfig
 
addMembers(Collection<Member>) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
addMembers(Collection<Member>) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
addMembers(Collection<Member>) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
addMembershipListener(MembershipListener) - Method in class com.hazelcast.client.proxy.ClientClusterProxy
 
addMembershipListener(MembershipListener) - Method in interface com.hazelcast.client.spi.ClientClusterService
 
addMembershipListener(MembershipListener) - Method in class com.hazelcast.client.spi.impl.ClientClusterServiceImpl
 
addMembershipListener(MembershipListener) - Method in interface com.hazelcast.core.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.proxy.ClientReliableTopicProxy
 
addMessageListener(MessageListener<E>) - Method in class com.hazelcast.client.proxy.ClientTopicProxy
 
addMessageListener(MessageListener<E>) - Method in interface com.hazelcast.core.ITopic
Subscribes to this topic.
addMessageListener(MessageListener<E>) - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicProxy
 
addMessageListener(MessageListener<E>) - Method in class com.hazelcast.topic.impl.TopicProxy
 
addMessageListener(String, MessageListener, boolean) - Method in class com.hazelcast.topic.impl.TopicService
 
addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.ReliableTopicConfig
Adds a message listener (listens for when messages are added or removed) to this reliable topic.
addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.TopicConfig
Adds a message listener to this topic (listens for when messages are added or removed).
addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.TopicConfigReadOnly
Deprecated.
 
addMessageListenerInternal(MessageListener) - Method in class com.hazelcast.topic.impl.TopicProxySupport
 
addMigrationListener(MigrationListener) - Method in class com.hazelcast.client.proxy.PartitionServiceProxy
 
addMigrationListener(MigrationListener) - Method in interface com.hazelcast.core.PartitionService
Adds a MigrationListener.
addMigrationListener(MigrationListener) - Method in class com.hazelcast.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.spi.partition.IPartitionService
 
addMulticastListener(MulticastListener) - Method in class com.hazelcast.internal.cluster.impl.MulticastService
 
addMultiMapConfig(MultiMapConfig) - Method in class com.hazelcast.client.impl.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(String, NearCacheConfig) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated.
addNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.client.config.ClientConfig
Helper method to add a new NearCacheConfig
addNearCacheInvalidationListener(EventHandler) - Method in class com.hazelcast.client.cache.impl.NearCachedClientCacheProxy
 
addNearCacheInvalidationListener(EventHandler) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
 
addNearCacheInvalidationListener(EventHandler) - Method in class com.hazelcast.client.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 class 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.crdt.pncounter.operations
Addition/subtraction operation for a PNCounter.
AddOperation(String, long, boolean, VectorClock) - Constructor for class com.hazelcast.crdt.pncounter.operations.AddOperation
Creates the addition operation.
AddOperation() - Constructor for class com.hazelcast.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.CallsPerMember
 
addOrGetIndex(String, boolean) - Method in class com.hazelcast.query.impl.Indexes
 
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.NetworkConfig
 
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.NetworkConfig
 
addOwnershipMapping(String, String) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
addPartitionIndexToAdd(IndexInfo) - Method in class com.hazelcast.map.impl.MapContainer
 
addPartitionListener(PartitionListener) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
 
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.proxy.ClientMapProxy
 
addPartitionLostListener(PartitionLostListener) - Method in class com.hazelcast.client.proxy.PartitionServiceProxy
 
addPartitionLostListener(MapPartitionLostListener) - Method in interface com.hazelcast.core.IMap
Adds a MapPartitionLostListener.
addPartitionLostListener(PartitionLostListener) - Method in interface com.hazelcast.core.PartitionService
Adds a PartitionLostListener.
addPartitionLostListener(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, 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.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.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
 
addProcessedRecords(int) - Method in class com.hazelcast.mapreduce.impl.task.JobProcessInformationImpl
 
addProperty(String, Comparable) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
 
addProperty(String, String) - Method in class com.hazelcast.config.ServiceConfig
 
addProxyFactoryConfig(ProxyFactoryConfig) - Method in class com.hazelcast.client.config.ClientConfig
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.ProxyService
 
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.
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.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
 
addQuorumConfig(QuorumConfig) - Method in class com.hazelcast.client.impl.ClientDynamicClusterConfig
 
addQuorumConfig(QuorumConfig) - Method in class com.hazelcast.config.Config
Adds the split-brain protection configuration.
addQuorumConfig(QuorumConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
addQuorumListener(String, QuorumListener) - Method in class com.hazelcast.quorum.impl.QuorumServiceImpl
 
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.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.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.instance.AbstractMember
 
address - Variable in class com.hazelcast.instance.Node
 
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
 
address() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray
 
address() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
 
Address - Class in com.hazelcast.nio
Represents an address of a member in the cluster.
Address() - Constructor for class com.hazelcast.nio.Address
 
Address(String, int) - Constructor for class com.hazelcast.nio.Address
 
Address(InetAddress, int) - Constructor for class com.hazelcast.nio.Address
 
Address(InetSocketAddress) - Constructor for class com.hazelcast.nio.Address
Creates a new Address
Address(String, InetAddress, int) - Constructor for class com.hazelcast.nio.Address
 
Address(Address) - Constructor for class com.hazelcast.nio.Address
 
address - Variable in class com.hazelcast.util.AddressUtil.AddressMatcher
 
addresses() - Method in class com.hazelcast.spi.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.util.AddressUtil.AddressHolder
 
AddressMatcher(String[]) - Constructor for class com.hazelcast.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.connection
Provides initial addresses for client to find and connect to a node
AddressTranslator - Interface in com.hazelcast.client.connection
Address Translator is used for resolve private ip addresses of cloud services.
AddressUtil - Class in com.hazelcast.util
AddressUtil contains Address helper methods.
AddressUtil.AddressHolder - Class in com.hazelcast.util
Holds address
AddressUtil.AddressMatcher - Class in com.hazelcast.util
http://docs.oracle.com/javase/1.5.0/docs/guide/net/ipv6_guide/index.html
AddressUtil.InvalidAddressException - Exception in com.hazelcast.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.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.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.client.impl.ClientDynamicClusterConfig
 
addSemaphoreConfig(SemaphoreConfig) - Method in class com.hazelcast.config.Config
Adds the ISemaphore configuration.
addSemaphoreConfig(SemaphoreConfig) - Method in class com.hazelcast.internal.dynamicconfig.DynamicConfigurationAwareConfig
 
AddSemaphoreConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.dynamicconfig
 
AddSemaphoreConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.dynamicconfig.AddSemaphoreConfigMessageTask
 
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.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
 
addStoreListener(StoreListener) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
 
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.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.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
 
AddWanConfigOperation - Class in com.hazelcast.internal.management.operation
Operation to add a new WanReplicationConfig at runtime.
AddWanConfigOperation() - Constructor for class com.hazelcast.internal.management.operation.AddWanConfigOperation
 
AddWanConfigOperation(WanReplicationConfig) - Constructor for class com.hazelcast.internal.management.operation.AddWanConfigOperation
 
addWanPublisherConfig(WanPublisherConfig) - Method in class com.hazelcast.config.WanReplicationConfig
 
addWanReplicationConfig(WanReplicationConfig) - Method in class com.hazelcast.client.impl.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 class com.hazelcast.wan.impl.WanReplicationServiceImpl
 
addWanReplicationConfig(WanReplicationConfig) - Method in interface com.hazelcast.wan.WanReplicationService
Adds a new WanReplicationConfig to this member and creates the WanReplicationPublishers specified in the config.
adjustEstimateBy(long) - Method in interface com.hazelcast.map.impl.EntryCostEstimator
Adjust the memory cost estimation by the given adjustment.
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 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
 
advance() - Method in class com.hazelcast.util.collection.Long2LongHashMap.LongLongCursor
 
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
 
afterExecute(Runnable, Throwable) - Method in class com.hazelcast.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.
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.CacheGetAndRemoveOperation
 
afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
 
afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheLegacyMergeOperation
 
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.CacheRemoveOperation
 
afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
 
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.concurrent.lock.operations.UnlockOperation
 
afterRun() - Method in class com.hazelcast.crdt.AbstractCRDTReplicationOperation
 
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.map.impl.operation.BasePutOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.ClearExpiredOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.ClearOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.DeleteOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.EvictBackupOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.EvictOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.GetOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.LegacyMergeOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.LoadAllOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.MergeOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllBackupOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.PutIfAbsentOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.RemoveBackupOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.RemoveIfSameOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.RemoveOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.ReplaceOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.SetOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
 
afterRun() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
 
afterRun() - Method in class com.hazelcast.multimap.impl.operations.ClearOperation
 
afterRun() - Method in class com.hazelcast.multimap.impl.operations.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.Operation
 
afterRun() - Method in class com.hazelcast.util.executor.HazelcastManagedThread
Called after inner run method and can be overridden to customize.
afterRunInternal() - Method in class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
 
afterRunInternal() - Method in class com.hazelcast.cache.impl.operation.CachePutBackupOperation
 
afterRunInternal() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
 
afterStart(HazelcastClientInstanceImpl) - Method in interface com.hazelcast.client.ClientExtension
Called after node is started
afterStart(HazelcastClientInstanceImpl) - Method in class com.hazelcast.client.impl.DefaultClientExtension
 
afterStart() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
afterStart() - Method in interface com.hazelcast.instance.NodeExtension
Called after node is started
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<Map.Entry<K, V>, R>) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
aggregate(Aggregator<Map.Entry<K, V>, R>, Predicate<K, V>) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
 
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
 
aggregate(Aggregator<Map.Entry<K, V>, R>) - Method in interface com.hazelcast.core.IMap
Applies the aggregation logic on all map entries and returns the result
aggregate(Aggregator<Map.Entry<K, V>, R>, Predicate<K, V>) - Method in interface com.hazelcast.core.IMap
Applies the aggregation logic on map entries filtered with the Predicated and returns the result
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in interface com.hazelcast.core.IMap
Deprecated.
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in interface com.hazelcast.core.IMap
Deprecated.
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in interface com.hazelcast.core.MultiMap
Deprecated.
The old Aggregations API is superseded by Fast Aggregations (com.hazelcast.aggregation) which does not yet support MultiMap. Hazelcast Jet can be used in the future to replace this functionality.
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in interface com.hazelcast.core.MultiMap
Deprecated.
The old Aggregations API is superseded by Fast Aggregations (com.hazelcast.aggregation) which does not yet support MultiMap. Hazelcast Jet can be used in the future to replace this functionality.
aggregate(Map<K, V>, Map<K, V>) - Static method in class com.hazelcast.internal.dynamicconfig.AggregatingMap
Creates new aggregating maps.
aggregate(Aggregator<Map.Entry<K, V>, R>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
aggregate(Aggregator<Map.Entry<K, V>, R>, Predicate<K, V>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
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
 
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<Key,Supplied,Result> - Interface in com.hazelcast.mapreduce.aggregation
Deprecated.
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
 
Aggregations - Class in com.hazelcast.mapreduce.aggregation
Deprecated.
Use fast-aggregations Aggregators
AGGREGATIONS_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
AGGREGATIONS_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
AggregationsDataSerializerHook - Class in com.hazelcast.mapreduce.aggregation.impl
This class contains all the ID hooks for IdentifiedDataSerializable classes used for aggregations.
AggregationsDataSerializerHook() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
Aggregator<I,R> - Class in com.hazelcast.aggregation
Base class for all aggregators.
Aggregator() - Constructor for class com.hazelcast.aggregation.Aggregator
 
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.
AggType<KeyIn,ValueIn,KeyOut,SuppliedValue,CombinerValue,ReducerValue,Result> - Interface in com.hazelcast.mapreduce.aggregation.impl
The internal interface for Aggregation definitions to make those implementations more type-safe.
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.connection.nio.ClientConnectionManagerImpl
 
all() - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
Deprecated.
The predefined Supplier selects all values and does not perform any kind of data transformation.
all(PropertyExtractor<ValueIn, ValueOut>) - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
Deprecated.
The predefined Supplier selects all values and performs the given PropertyExtractors transformation to the input data.
ALL_NODES - Static variable in class com.hazelcast.map.impl.query.Target
 
allDone(Collection<Future>) - Static method in class com.hazelcast.util.FutureUtil
Check if all futures are done
allNodes() - Method in class com.hazelcast.map.impl.query.Target.TargetBuilder
 
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
 
ALLOW_INVOCATIONS_WHEN_DISCONNECTED - Static variable in class com.hazelcast.client.spi.properties.ClientProperty
Client disallows doing invocations on client disconnected state.
AllowedDuringPassiveState - Interface in com.hazelcast.spi.impl
Marker interface for operations those are allowed to be executed or invoked during Node's NodeState.PASSIVE state.
AllowedDuringPassiveStateTransactionImpl - Class in com.hazelcast.transaction.impl
 
AllowedDuringPassiveStateTransactionImpl(TransactionManagerServiceImpl, NodeEngine, TransactionOptions, String) - Constructor for class com.hazelcast.transaction.impl.AllowedDuringPassiveStateTransactionImpl
 
allowsLock(String) - Method in class com.hazelcast.internal.util.LockGuard
 
allowsUnlock(String) - Method in class com.hazelcast.internal.util.LockGuard
 
allowUnsafe - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
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
 
alter(IFunction<Long, Long>) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
 
alter(IFunction<E, E>) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
 
ALTER - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
alter(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
ALTER - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
alter(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
alter(IFunction<Long, Long>) - Method in interface com.hazelcast.core.IAtomicLong
Alters the currently stored value by applying a function on it.
alter(IFunction<E, E>) - Method in interface com.hazelcast.core.IAtomicReference
Alters the currently stored reference by applying a function on it.
ALTER_AND_GET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
ALTER_AND_GET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
alterAndGet(IFunction<Long, Long>) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
 
alterAndGet(IFunction<E, E>) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
 
alterAndGet(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
alterAndGet(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
alterAndGet(IFunction<Long, Long>) - Method in interface com.hazelcast.core.IAtomicLong
Alters the currently stored value by applying a function on it and gets the result.
alterAndGet(IFunction<E, E>) - Method in interface com.hazelcast.core.IAtomicReference
Alters the currently stored reference by applying a function on it and gets the result.
alterAndGetAsync(IFunction<Long, Long>) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
 
alterAndGetAsync(IFunction<E, E>) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
 
alterAndGetAsync(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
alterAndGetAsync(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
alterAndGetAsync(IFunction<Long, Long>) - Method in interface com.hazelcast.core.IAtomicLong
Alters the currently stored value by applying a function on it and gets the result.
alterAndGetAsync(IFunction<E, E>) - Method in interface com.hazelcast.core.IAtomicReference
Alters the currently stored reference by applying a function on it and gets the result.
AlterAndGetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AlterAndGetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterAndGetOperation
 
AlterAndGetOperation(String, IFunction<Long, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterAndGetOperation
 
AlterAndGetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
AlterAndGetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterAndGetOperation
 
AlterAndGetOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterAndGetOperation
 
alterAsync(IFunction<Long, Long>) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
 
alterAsync(IFunction<E, E>) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
 
alterAsync(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
alterAsync(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
alterAsync(IFunction<Long, Long>) - Method in interface com.hazelcast.core.IAtomicLong
Alters the currently stored value by applying a function on it.
alterAsync(IFunction<E, E>) - Method in interface com.hazelcast.core.IAtomicReference
Alters the currently stored reference by applying a function on it.
AlterOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AlterOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterOperation
 
AlterOperation(String, IFunction<Long, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterOperation
 
AlterOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
AlterOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterOperation
 
AlterOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterOperation
 
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 class com.hazelcast.query.Predicates
Creates an always false predicate that will filter out all items.
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(Predicate) - Method in class 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
 
AndPredicate - Class in com.hazelcast.query.impl.predicates
And Predicate
AndPredicate() - Constructor for class com.hazelcast.query.impl.predicates.AndPredicate
 
AndPredicate(Predicate...) - Constructor for class com.hazelcast.query.impl.predicates.AndPredicate
 
AndResultSet - Class in com.hazelcast.query.impl
And Result set for Predicates.
AndResultSet(Set<QueryableEntry>, List<Set<QueryableEntry>>, List<Predicate>) - Constructor for class com.hazelcast.query.impl.AndResultSet
 
andThen(ExecutionCallback<ClientMessage>) - Method in class com.hazelcast.client.spi.impl.ClientInvocationFuture
 
andThen(ExecutionCallback<ClientMessage>, Executor) - Method in class com.hazelcast.client.spi.impl.ClientInvocationFuture
 
andThen(ExecutionCallback<V>) - Method in class com.hazelcast.client.util.ClientDelegatingFuture
 
andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.client.util.ClientDelegatingFuture
 
andThen(ExecutionCallback<V>) - Method in interface com.hazelcast.core.ICompletableFuture
Registers a callback that will run after the future is completed.
andThen(ExecutionCallback<V>, Executor) - Method in interface com.hazelcast.core.ICompletableFuture
Registers a callback that will run with the provided executor after the future is completed.
andThen(ExecutionCallback<V>) - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
 
andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
 
andThen(ExecutionCallback<V>) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
 
andThen(ExecutionCallback<V>) - Method in class com.hazelcast.util.executor.CompletedFuture
 
andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.util.executor.CompletedFuture
 
andThen(ExecutionCallback<V>) - Method in class com.hazelcast.util.executor.DelegatingFuture
 
andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.util.executor.DelegatingFuture
 
andThenInternal(ExecutionCallback<T>, boolean) - Method in class com.hazelcast.client.util.ClientDelegatingFuture
Uses internal executor to execute callbacks instead of ClientDelegatingFuture.userExecutor.
answerWhoisMasterQuestion(JoinMessage, Connection) - Method in class com.hazelcast.internal.cluster.impl.ClusterJoinManager
Respond to a WhoisMasterOp.
ANY_THREAD - Static variable in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
 
append(ClientProtocolBuffer, int, int) - Method in class com.hazelcast.client.impl.protocol.util.BufferBuilder
Append a source buffer to the end of the internal buffer, resizing the internal buffer as required.
appendToken(StringBuilder, StringBuilder) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
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.proxy.ClientAtomicLongProxy
 
apply(IFunction<E, R>) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
 
APPLY - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
apply(IFunction<Long, R>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
APPLY - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
apply(IFunction<E, R>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
apply(IFunction<Long, R>) - Method in interface com.hazelcast.core.IAtomicLong
Applies a function on the value, the actual stored value will not change.
apply(IFunction<E, R>) - Method in interface com.hazelcast.core.IAtomicReference
Applies a function on the value, the actual stored value will not change.
apply(T, U) - Method in interface com.hazelcast.core.IBiFunction
Applies this function to the given arguments.
apply(T) - Method in interface com.hazelcast.core.IFunction
 
apply(K) - Method in class com.hazelcast.internal.nearcache.impl.store.AbstractNearCacheRecordStore.ReserveForUpdateFunction
 
apply(Map.Entry<KeyIn, ValueIn>) - Method in class com.hazelcast.mapreduce.aggregation.impl.AcceptAllSupplier
 
apply(Map.Entry<KeyIn, ValueIn>) - Method in class com.hazelcast.mapreduce.aggregation.impl.KeyPredicateSupplier
 
apply(Map.Entry<KeyIn, ValueIn>) - Method in class com.hazelcast.mapreduce.aggregation.impl.PredicateSupplier
 
apply(Map.Entry<KeyIn, ValueIn>) - Method in class com.hazelcast.mapreduce.aggregation.Supplier
Deprecated.
The apply method is used to apply the actual filtering or extraction / transformation to the input entry.
If the input value should be ignored by the aggregation, the Supplier has to return
apply(Map.Entry<K, V>) - Method in class com.hazelcast.query.impl.FalsePredicate
 
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.InstanceOfPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.NotEqualPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.NotPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.OrPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.PagingPredicate
Used for delegating filtering to inner predicate.
apply(Map.Entry<K, V>) - Method in class com.hazelcast.query.PartitionPredicate
 
apply(Map.Entry<K, V>) - Method in interface com.hazelcast.query.Predicate
Applies this predicate to the given map entry.
apply(Map.Entry) - Method in class com.hazelcast.query.PredicateBuilder
 
apply(Map.Entry) - Method in class com.hazelcast.query.SqlPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.TruePredicate
 
apply(Collection<Member>) - Method in class com.hazelcast.quorum.impl.ProbabilisticQuorumFunction
 
apply(Collection<Member>) - Method in class com.hazelcast.quorum.impl.RecentlyActiveQuorumFunction
 
apply(Collection<Member>) - Method in interface com.hazelcast.quorum.QuorumFunction
Determines if quorum is present based on the current list of members in the cluster.
apply(int) - Method in interface com.hazelcast.util.function.IntFunction
Applies this function to the given argument.
apply(long) - Method in interface com.hazelcast.util.function.LongFunction
Applies this function to the given argument.
applyAsync(IFunction<Long, R>) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
 
applyAsync(IFunction<E, R>) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
 
applyAsync(IFunction<Long, R>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
applyAsync(IFunction<E, R>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
applyAsync(IFunction<Long, R>) - Method in interface com.hazelcast.core.IAtomicLong
Applies a function on the value, the actual stored value will not change.
applyAsync(IFunction<E, R>) - Method in interface com.hazelcast.core.IAtomicReference
Applies a function on the value, the actual stored value will not change.
applyChanges() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
Provides a similar functionality as committing a transaction.
applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
 
applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
 
applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
 
applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
 
applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.InPredicate
 
applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.LikePredicate
 
applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.RegexPredicate
 
applyIfAbsent(K, IFunction<? super K, ? extends V>) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
applyIfAbsent(K, IFunction<? super K, ? extends V>) - Method in interface com.hazelcast.util.IConcurrentMap
applyIfPresent(K, IBiFunction<? super K, ? super V, ? extends V>) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
 
applyIfPresent(K, IBiFunction<? super K, ? super V, ? extends V>) - Method in interface com.hazelcast.util.IConcurrentMap
ApplyOperation<R> - Class in com.hazelcast.concurrent.atomiclong.operations
 
ApplyOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
 
ApplyOperation(String, IFunction<Long, R>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
 
ApplyOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
ApplyOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
 
ApplyOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
 
applyRecordInfo(Record, RecordInfo) - Static method in class com.hazelcast.map.impl.record.Records
 
applyState() - Method in class com.hazelcast.cache.impl.operation.CacheNearCacheStateHolder
 
ArgumentParser<I,O> - Class in com.hazelcast.query.extractor
Common superclass for all argument parsers.
ArgumentParser() - Constructor for class com.hazelcast.query.extractor.ArgumentParser
 
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_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
 
ArrayDataSerializableFactory - Class in com.hazelcast.internal.serialization.impl
 
ArrayDataSerializableFactory(ConstructorFunction<Integer, IdentifiedDataSerializable>[]) - Constructor for class com.hazelcast.internal.serialization.impl.ArrayDataSerializableFactory
 
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 - Class in com.hazelcast.internal.serialization.impl
The ArrayList serializer
ArrayListStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ArrayListStreamSerializer
 
ArrayRingbuffer<E> - Class in com.hazelcast.ringbuffer.impl
The ArrayRingbuffer is responsible for storing the actual content of a ringbuffer.
ArrayRingbuffer(int) - Constructor for class com.hazelcast.ringbuffer.impl.ArrayRingbuffer
 
ArrayUtils - Class in com.hazelcast.util.collection
Convenient method for array manipulations.
asCacheConfig(CacheConfig) - Static method in class com.hazelcast.cache.impl.PreJoinCacheConfig
 
asCompletableFuture(Future<V>) - Method in interface com.hazelcast.spi.ExecutionService
 
asCompletableFuture(Future<V>) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
 
asElementIterable(NodeList) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
 
asEvictionConfg(SerializationService) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.EvictionConfigHolder
 
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
 
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
 
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
 
asReadOnly() - Method in class com.hazelcast.config.MemberAttributeConfig
Deprecated.
this method will be removed in 4.0; it is meant for internal usage only
asRingbufferStoreConfig(SerializationService) - Method in class com.hazelcast.client.impl.protocol.task.dynamicconfig.RingbufferStoreConfigHolder
 
ASSERTION_ERROR - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
assertRunningOnPartitionThread() - Static method in class com.hazelcast.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
 
assignKeyReducerAddress(Object) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
 
assignKeyReducerAddress(Object, Address) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
 
assignMemberId(Address, String, JobTaskConfiguration) - Method in class com.hazelcast.mapreduce.impl.task.MemberAssigningJobProcessInformationImpl
 
AssignPartitions - Class in com.hazelcast.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
 
asVersion() - Method in class com.hazelcast.version.MemberVersion
 
ASYNC_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the async executor.
ASYNC_RESULT_WAIT_TIMEOUT_MINUTES - Static variable in class com.hazelcast.internal.nearcache.impl.invalidation.MetaDataFetcher
 
asyncAddAndGet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncAddAndGet(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically adds the given value to the current value.
asyncAlter(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncAlter(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncAlter(IFunction<Long, Long>) - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Alters the currently stored value by applying a function on it.
asyncAlter(IFunction<E, E>) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Alters the currently stored reference by applying a function on it.
asyncAlterAndGet(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncAlterAndGet(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncAlterAndGet(IFunction<Long, Long>) - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Alters the currently stored value by applying a function on it and gets the result.
asyncAlterAndGet(IFunction<E, E>) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Alters the currently stored reference by applying a function on it and gets the result.
asyncApply(IFunction<Long, R>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncApply(IFunction<E, R>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncApply(IFunction<Long, R>) - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Applies a function on the value, the actual stored value will not change.
asyncApply(IFunction<E, R>) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Applies a function on the value, the actual stored value will not change.
AsyncAtomicLong - Interface in com.hazelcast.core
Deprecated.
AsyncAtomicReference<E> - Interface in com.hazelcast.core
Deprecated.
asyncClear() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncClear() - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Clears the current stored reference.
asyncCompareAndSet(long, long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncCompareAndSet(E, E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncCompareAndSet(long, long) - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically sets the value to the given updated value only if the current value == the expected value.
asyncCompareAndSet(E, E) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Atomically sets the value to the given updated value only if the current value == the expected value.
AsyncConsoleRequest - Interface in com.hazelcast.internal.management.request
Represents async requests sent from Management Center.
asyncContains(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncContains(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Checks if the reference contains the value.
asyncDecrementAndGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncDecrementAndGet() - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically decrements the current value by one.
asyncGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncGet() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncGet() - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Gets the current value.
asyncGet() - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Gets the current value.
asyncGetAndAdd(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncGetAndAdd(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically adds the given value to the current value.
asyncGetAndAlter(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncGetAndAlter(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncGetAndAlter(IFunction<Long, Long>) - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Alters the currently stored value by applying a function on it on and gets the old value.
asyncGetAndAlter(IFunction<E, E>) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Alters the currently stored reference by applying a function on it on and gets the old value.
asyncGetAndIncrement() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncGetAndIncrement() - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically increments the current value by one.
asyncGetAndSet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncGetAndSet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncGetAndSet(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically sets the given value and returns the old value.
asyncGetAndSet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Gets the value and sets the new value.
asyncIncrementAndGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncIncrementAndGet() - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically increments the current value by one.
asyncInvokeOnPartition(String, Operation, int, ExecutionCallback<V>) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
 
asyncInvokeOnPartition(String, Operation, int, ExecutionCallback<V>) - Method in interface com.hazelcast.spi.impl.operationservice.InternalOperationService
 
asyncIsNull() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncIsNull() - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Checks if the stored reference is null.
asyncSet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncSet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncSet(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
Deprecated.
Atomically sets the given value.
asyncSet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
Atomically sets the given value.
asyncSetAndGet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncSetAndGet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated.
will be removed from Hazelcast 3.4 since it doesn't really serve a purpose.
ATOMIC_LONG_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
ATOMIC_LONG_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ATOMIC_LONG_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ATOMIC_LONG_MERGING_VALUE - Static variable in class com.hazelcast.spi.impl.merge.SplitBrainDataSerializerHook
 
ATOMIC_LONG_NAME - Static variable in class com.hazelcast.concurrent.idgen.IdGeneratorService
 
ATOMIC_LONG_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ATOMIC_LONG_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ATOMIC_REFERENCE_CONFIG - Static variable in class com.hazelcast.config.ConfigDataSerializerHook
 
ATOMIC_REFERENCE_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ATOMIC_REFERENCE_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
 
ATOMIC_REFERENCE_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
 
AtomicLongAddAndGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
 
AtomicLongAddAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAddAndGetMessageTask
 
AtomicLongAlterAndGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
 
AtomicLongAlterAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterAndGetMessageTask
 
AtomicLongAlterMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
 
AtomicLongAlterMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterMessageTask
 
AtomicLongApplyMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
 
AtomicLongApplyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongApplyMessageTask
 
AtomicLongBackupAwareOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AtomicLongBackupAwareOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
 
AtomicLongBackupAwareOperation(String) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
 
AtomicLongCompareAndSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
 
AtomicLongCompareAndSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongCompareAndSetMessageTask
 
AtomicLongConfig - Class in com.hazelcast.config
Contains the configuration for an AtomicLong.
AtomicLongConfig(String) - Constructor for class com.hazelcast.config.AtomicLongConfig
 
AtomicLongConfig(AtomicLongConfig) - Constructor for class com.hazelcast.config.AtomicLongConfig
 
AtomicLongContainer - Class in com.hazelcast.concurrent.atomiclong
 
AtomicLongContainer() - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
 
AtomicLongDataSerializerHook - Class in com.hazelcast.concurrent.atomiclong
 
AtomicLongDataSerializerHook() - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
AtomicLongDecrementAndGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
 
AtomicLongDecrementAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongDecrementAndGetMessageTask
 
AtomicLongGetAndAddMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
 
AtomicLongGetAndAddMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAddMessageTask
 
AtomicLongGetAndAlterMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
 
AtomicLongGetAndAlterMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAlterMessageTask
 
AtomicLongGetAndIncrementMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
 
AtomicLongGetAndIncrementMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndIncrementMessageTask
 
AtomicLongGetAndSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
 
AtomicLongGetAndSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndSetMessageTask
 
AtomicLongGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
 
AtomicLongGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetMessageTask
 
AtomicLongIncrementAndGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
 
AtomicLongIncrementAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongIncrementAndGetMessageTask
 
AtomicLongMBean - Class in com.hazelcast.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.concurrent.atomiclong
 
AtomicLongProxy(String, NodeEngine, AtomicLongService) - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
AtomicLongReplicationOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AtomicLongReplicationOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
 
AtomicLongReplicationOperation(Map<String, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
 
AtomicLongService - Class in com.hazelcast.concurrent.atomiclong
 
AtomicLongService() - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
AtomicLongSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
 
AtomicLongSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongSetMessageTask
 
AtomicReferenceAlterAndGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
 
AtomicReferenceAlterAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterAndGetMessageTask
 
AtomicReferenceAlterMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
 
AtomicReferenceAlterMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterMessageTask
 
AtomicReferenceApplyMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
 
AtomicReferenceApplyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceApplyMessageTask
 
AtomicReferenceBackupAwareOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
AtomicReferenceBackupAwareOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
 
AtomicReferenceBackupAwareOperation(String) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
 
AtomicReferenceClearMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
 
AtomicReferenceClearMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceClearMessageTask
 
AtomicReferenceCompareAndSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
 
AtomicReferenceCompareAndSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceCompareAndSetMessageTask
 
AtomicReferenceConfig - Class in com.hazelcast.config
Contains the configuration for an AtomicReference.
AtomicReferenceConfig(String) - Constructor for class com.hazelcast.config.AtomicReferenceConfig
 
AtomicReferenceConfig(AtomicReferenceConfig) - Constructor for class com.hazelcast.config.AtomicReferenceConfig
 
AtomicReferenceContainer - Class in com.hazelcast.concurrent.atomicreference
 
AtomicReferenceContainer() - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
 
AtomicReferenceContainsMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
 
AtomicReferenceContainsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceContainsMessageTask
 
AtomicReferenceDataSerializerHook - Class in com.hazelcast.concurrent.atomicreference
 
AtomicReferenceDataSerializerHook() - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
AtomicReferenceGetAndAlterMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
 
AtomicReferenceGetAndAlterMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndAlterMessageTask
 
AtomicReferenceGetAndSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
 
AtomicReferenceGetAndSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndSetMessageTask
 
AtomicReferenceGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
 
AtomicReferenceGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetMessageTask
 
AtomicReferenceIsNullMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
 
AtomicReferenceIsNullMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceIsNullMessageTask
 
AtomicReferenceMBean - Class in com.hazelcast.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
 
AtomicReferenceProxy<E> - Class in com.hazelcast.concurrent.atomicreference
 
AtomicReferenceProxy(String, NodeEngine, AtomicReferenceService) - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
AtomicReferenceReplicationOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
AtomicReferenceReplicationOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
 
AtomicReferenceReplicationOperation(Map<String, Data>) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
 
AtomicReferenceService - Class in com.hazelcast.concurrent.atomicreference
 
AtomicReferenceService() - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
AtomicReferenceSetAndGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
 
AtomicReferenceSetAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetAndGetMessageTask
 
AtomicReferenceSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
 
AtomicReferenceSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetMessageTask
 
attributeMap - Variable in class com.hazelcast.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.instance.AbstractMember
 
AttributeType - Enum in com.hazelcast.query.impl
Type of Attribute
AUTH_FAILURE - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
authenticated(ClientPrincipal, Credentials, boolean, String, long) - Method in interface com.hazelcast.client.ClientEndpoint
 
authenticated(ClientPrincipal) - Method in interface com.hazelcast.client.ClientEndpoint
 
authenticated(ClientPrincipal, Credentials, boolean, String, long) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
authenticated(ClientPrincipal) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
AUTHENTICATION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
 
AuthenticationBaseMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
Base authentication task
AuthenticationBaseMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
 
AuthenticationCustomCredentialsMessageTask - Class in com.hazelcast.client.impl.protocol.task
Custom Authentication with custom credential impl
AuthenticationCustomCredentialsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
 
AuthenticationException - Exception in com.hazelcast.client
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
AUTHORIZATION - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
AuthorizationOp - Class in com.hazelcast.internal.cluster.impl.operations
 
AuthorizationOp() - Constructor for class com.hazelcast.internal.cluster.impl.operations.AuthorizationOp
 
AuthorizationOp(String, String) - Constructor for class com.hazelcast.internal.cluster.impl.operations.AuthorizationOp
 
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_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
AvailableOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
AvailableOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.AvailableOperation
 
AvailableOperation(String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.AvailableOperation
 
availablePermits() - Method in class com.hazelcast.client.proxy.ClientSemaphoreProxy
 
availablePermits() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
availablePermits() - Method in interface com.hazelcast.core.ISemaphore
Returns the current number of permits currently available in this semaphore.
AVG_TUPLE - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
AvgTuple<F,S> - Class in com.hazelcast.mapreduce.aggregation.impl
Internal tuple type for average calculations, used to transmit data between Combiner and Reducer implementations.
AvgTuple(F, S) - Constructor for class com.hazelcast.mapreduce.aggregation.impl.AvgTuple
 
await() - Method in class com.hazelcast.client.proxy.ClientConditionProxy
 
await(long, TimeUnit) - Method in class com.hazelcast.client.proxy.ClientConditionProxy
 
await(long, TimeUnit) - Method in class com.hazelcast.client.proxy.ClientCountDownLatchProxy
 
await(long, TimeUnit) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
 
AWAIT - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
await(long, TimeUnit) - Method in interface com.hazelcast.core.ICountDownLatch
Causes the current thread to wait until the latch has counted down to zero, or an exception is thrown, or the specified waiting time elapses.
AWAIT_BACKUP - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
AWAIT_COMPLETION_TIMEOUT_SECONDS - Static variable in class com.hazelcast.cache.impl.CacheProxyUtil
 
AWAIT_MAP_FLUSH - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
 
AWAIT_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
 
AwaitBackupOperation - Class in com.hazelcast.concurrent.lock.operations
 
AwaitBackupOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitBackupOperation
 
AwaitBackupOperation(ObjectNamespace, Data, long, String, String) - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitBackupOperation
 
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.
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
 
awaitNanos(long) - Method in class com.hazelcast.client.proxy.ClientConditionProxy
 
AwaitOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
 
AwaitOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
 
AwaitOperation(String, long) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
 
AwaitOperation - Class in com.hazelcast.concurrent.lock.operations
 
AwaitOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitOperation
 
AwaitOperation(ObjectNamespace, Data, long, long, String) - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitOperation
 
AwaitOperation(ObjectNamespace, Data, long, long, String, long) - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitOperation
 
awaitTermination(long, TimeUnit) - Method in class com.hazelcast.client.proxy.ClientDurableExecutorServiceProxy
 
awaitTermination(long, TimeUnit) - Method in class com.hazelcast.client.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(int, TimeUnit) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationThread
 
awaitTermination(long) - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationMonitor
 
awaitTermination(long, TimeUnit) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
awaitUninterruptibly() - Method in class com.hazelcast.client.proxy.ClientConditionProxy
 
awaitUntil(Date) - Method in class com.hazelcast.client.proxy.ClientConditionProxy
 
AwsAddressProvider - Class in com.hazelcast.client.spi.impl
Calls the AWS API to load ip addresses related to given credentials.
AwsAddressProvider(ClientAwsConfig, LoggingService) - Constructor for class com.hazelcast.client.spi.impl.AwsAddressProvider
 
AwsAddressTranslator - Class in com.hazelcast.client.spi.impl
AwsAddressTranslator loads EC2 IP addresses with given AWS credentials.
AwsAddressTranslator(ClientAwsConfig, LoggingService) - Constructor for class com.hazelcast.client.spi.impl.AwsAddressTranslator
 
AwsConfig - Class in com.hazelcast.config
The AWSConfig contains the configuration for AWS join mechanism.
AwsConfig() - Constructor for class com.hazelcast.config.AwsConfig
 

B

BackoffIdleStrategy - Class in com.hazelcast.util.concurrent
Idling strategy for threads when they have no work to do.
BackoffIdleStrategy(long, long, long, long) - Constructor for class com.hazelcast.util.concurrent.BackoffIdleStrategy
Create a set of state tracking idle behavior
BACKPRESSURE_BACKOFF_TIMEOUT_MILLIS - Static variable in class com.hazelcast.client.spi.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 - Variable in class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
 
backup - Variable in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
 
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.hotrestart.NoOpHotRestartService
 
backup(long) - Method in class com.hazelcast.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(Data, Address, long[], boolean) - 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_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_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
A BackupAwareOperation is an Operation to indicate then when a change is made, a BackupOperation is created to replicate the backup.
backupHandler() - Method in class com.hazelcast.spi.impl.operationservice.impl.InboundResponseHandlerSupplier
 
BackupOperation - Interface in com.hazelcast.spi
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.AbstractCacheOperation
 
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.NioEventLoopGroup.Context
 
base() - Method in class com.hazelcast.flakeidgen.impl.IdBatch
Returns the first ID in the set.
Base64 - Class in com.hazelcast.util
This class provides encode/decode for RFC 2045 Base64 as defined by RFC 2045, N.
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
BaseMap<K,V> - Interface in com.hazelcast.core
Base interface for Hazelcast distributed maps.
BaseMultiMap<K,V> - Interface in com.hazelcast.core
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(String, Data, Data, long) - 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.core
Base interface for Hazelcast distributed queues.
BaseRemoveOperation - Class in com.hazelcast.map.impl.operation
 
BaseRemoveOperation(String, Data, boolean) - Constructor for class com.hazelcast.map.impl.operation.BaseRemoveOperation
 
BaseRemoveOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.BaseRemoveOperation
 
BaseRemoveOperation() - 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
 
BasicSSLContextFactory() - Constructor for class com.hazelcast.nio.ssl.BasicSSLContextFactory
 
BATCH_INVALIDATION_MESSAGE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
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, IFunction<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() - 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_AWAIT - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
BEFORE_AWAIT_BACKUP - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
BEFORE_JOIN_CHECK_FAILURE - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
 
BeforeAwaitBackupOperation - Class in com.hazelcast.concurrent.lock.operations
 
BeforeAwaitBackupOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.BeforeAwaitBackupOperation
 
BeforeAwaitBackupOperation(ObjectNamespace, Data, long, String, String) - Constructor for class com.hazelcast.concurrent.lock.operations.BeforeAwaitBackupOperation
 
BeforeAwaitOperation - Class in com.hazelcast.concurrent.lock.operations
 
BeforeAwaitOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
 
BeforeAwaitOperation(ObjectNamespace, Data, long, String) - Constructor for class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
 
BeforeAwaitOperation(ObjectNamespace, Data, long, String, long) - Constructor for class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
 
beforeGetConnection(Address) - Method in class com.hazelcast.client.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.connection.nio.DefaultClientConnectionStrategy
 
beforeJoin() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
beforeJoin() - Method in interface com.hazelcast.instance.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.spi.EventHandler
This method is called before registration request is sent to node.
beforeListenerRegister() - Method in class com.hazelcast.client.spi.impl.ClientPartitionServiceImpl
 
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.concurrent.atomiclong.AtomicLongService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.durableexecutor.impl.DistributedDurableExecutorService
 
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.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.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.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.MapGetMessageTask
 
beforeProcess() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
 
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.MapGetMessageTask
 
beforeResponse() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
 
beforeRun() - Method in class com.hazelcast.cache.impl.journal.CacheEventJournalSubscribeOperation
 
beforeRun() - Method in class com.hazelcast.cache.impl.operation.AbstractCacheOperation
 
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.CacheMergeOperation
 
beforeRun() - Method in class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
 
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.concurrent.lock.operations.BeforeAwaitOperation
 
beforeRun() - Method in class com.hazelcast.concurrent.lock.operations.SignalOperation
 
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
Checks the precondition that the start sequence is already available (in the event journal) or is the sequence of the next event to be added into the journal.
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.map.impl.journal.MapEventJournalSubscribeOperation
 
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.Operation
 
beforeRun() - Method in class com.hazelcast.topic.impl.PublishOperation
Increments the local statistics for the number of published messages.
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
 
beforeRun() - Method in class com.hazelcast.util.executor.HazelcastManagedThread
Called before inner run method and can be overridden to customize.
beforeShutdown() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
beforeShutdown() - Method in interface com.hazelcast.instance.NodeExtension
Called before Node.shutdown()
beforeStart(HazelcastClientInstanceImpl) - Method in interface com.hazelcast.client.ClientExtension
Called before client is started
beforeStart(HazelcastClientInstanceImpl) - Method in class com.hazelcast.client.impl.DefaultClientExtension
 
beforeStart() - Method in class com.hazelcast.instance.DefaultNodeExtension
 
beforeStart() - Method in interface com.hazelcast.instance.NodeExtension
Called before node is started
begin - Variable in class com.hazelcast.map.impl.operation.EntryOffloadableSetUnlockOperation
 
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_AND_END_FLAGS - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
Begin and End Flags
BEGIN_FLAG - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
Begin Flag
beginCombine() - Method in class com.hazelcast.mapreduce.Combiner
Deprecated.
This method is called before the first value is submitted to this Combiner instance.
beginReduce() - Method in class com.hazelcast.mapreduce.Reducer
Deprecated.
This method is called before the first value is submitted to this Reducer instance.
beginTransaction() - Method in class com.hazelcast.client.proxy.txn.TransactionContextProxy
 
beginTransaction() - Method in class com.hazelcast.client.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.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
 
BetweenVisitor - Class in com.hazelcast.query.impl.predicates
Replaces expression from (age >= X and age <= Y) into (age between X Y) It detects some predicates which are trivally false.
BetweenVisitor() - Constructor for class com.hazelcast.query.impl.predicates.BetweenVisitor
 
BiConsumer<T,U> - Interface in com.hazelcast.util.function
Represents an operation that accepts two input arguments and returns no result.
BIG_DECIMAL_AVG - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
BIG_DECIMAL_AVG_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_DECIMAL_AVG_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_DECIMAL_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
BIG_DECIMAL_MAX_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_DECIMAL_MAX_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_DECIMAL_MIN_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_DECIMAL_MIN_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_DECIMAL_SUM - Static variable in class com.hazelcast.aggregation.impl.AggregatorDataSerializerHook
 
BIG_DECIMAL_SUM_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_DECIMAL_SUM_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
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_AVG_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_INTEGER_AVG_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_INTEGER_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
BIG_INTEGER_MAX_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_INTEGER_MAX_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_INTEGER_MIN_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_INTEGER_MIN_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_INTEGER_SUM_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_INTEGER_SUM_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
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
 
bigDecimalAvg() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the BigDecimal average of all supplied values.
This aggregation is similar to:
BigDecimalAvgAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
The predefined average aggregation for values of type BigDecimal.
BigDecimalAvgAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.BigDecimalAvgAggregation
 
bigDecimalMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the BigDecimal maximum of all supplied values.
This aggregation is similar to:
BigDecimalMaxAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
The predefined maximum aggregation for values of type BigDecimal.
BigDecimalMaxAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMaxAggregation
 
bigDecimalMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigDecimalMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the BigDecimal minimum of all supplied values.
This aggregation is similar to:
BigDecimalMinAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
The predefined minimum aggregation for values of type BigDecimal.
BigDecimalMinAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMinAggregation
 
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
 
bigDecimalSum() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the BigDecimal sum of all supplied values.
This aggregation is similar to:
BigDecimalSumAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
The predefined sum aggregation for values of type BigDecimal.
BigDecimalSumAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.BigDecimalSumAggregation
 
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
 
bigIntegerAvg() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the BigInteger average of all supplied values.
This aggregation is similar to:
BigIntegerAvgAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
The predefined average aggregation for values of type BigInteger.
BigIntegerAvgAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.BigIntegerAvgAggregation
 
bigIntegerMax() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMax(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the BigInteger maximum of all supplied values.
This aggregation is similar to:
BigIntegerMaxAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
The predefined maximum aggregation for values of type BigInteger.
BigIntegerMaxAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMaxAggregation
 
bigIntegerMin() - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMin(String) - Static method in class com.hazelcast.aggregation.Aggregators
 
bigIntegerMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to find the BigInteger minimum of all supplied values.
This aggregation is similar to:
BigIntegerMinAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
The predefined minimum aggregation for values of type BigInteger.
BigIntegerMinAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMinAggregation
 
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
 
bigIntegerSum() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Deprecated.
Returns an aggregation to calculate the BigInteger sum of all supplied values.
This aggregation is similar to:
BigIntegerSumAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
The predefined sum aggregation for values of type BigInteger.
BigIntegerSumAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.BigIntegerSumAggregation
 
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.util.collection
Map that takes two part int key and associates with an object.
BiInt2ObjectMap() - Constructor for class com.hazelcast.util.collection.BiInt2ObjectMap
Construct an empty map
BiInt2ObjectMap(int, double) - Constructor for class com.hazelcast.util.collection.BiInt2ObjectMap
BiInt2ObjectMap.EntryConsumer<V> - Interface in com.hazelcast.util.collection
Handler for a map entry
BinaryInterface - Annotation Type in com.hazelcast.nio.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
 
BinaryOperationFactory() - Constructor for class com.hazelcast.spi.impl.BinaryOperationFactory
 
BinaryOperationFactory(Operation, NodeEngine) - Constructor for class com.hazelcast.spi.impl.BinaryOperationFactory
 
BinaryOperationFactory(Data) - Constructor for class com.hazelcast.spi.impl.BinaryOperationFactory
 
bind(ClientEndpoint) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
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
 
Bits - Class in com.hazelcast.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
 
BitSetUtils - Class in com.hazelcast.util
Convenient method for BitSet manipulations
blacklist(Address, boolean) - Method in interface com.hazelcast.cluster.Joiner
Deprecated.
Adds an address to the blacklist.
blacklist(Address, boolean) - Method in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
blacklistedAddresses - Variable in class com.hazelcast.internal.cluster.impl.AbstractJoiner
 
BLOCK_SIZE - Static variable in class com.hazelcast.concurrent.idgen.IdGeneratorImpl
 
BlockingOperation - Interface in com.hazelcast.spi
An interface that can be implemented by an operation that can block.
BOOLEAN_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
BOOLEAN_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
BOOLEAN_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
BOOLEAN_SIZE_IN_BYTES - Static variable in class com.hazelcast.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.
boundsCheck(int, int, int) - Static method in class com.hazelcast.util.collection.ArrayUtils
Bounds check when copying to/from a buffer
BROADCAST_TX_ROLLBACK - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
 
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(String) - Constructor for class com.hazelcast.transaction.impl.operations.BroadcastTxRollbackOperation
 
buffer() - Method in class com.hazelcast.client.impl.protocol.util.BufferBuilder
The ClientProtocolBuffer that encapsulates the internal buffer.
buffer - Variable in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
 
buffer() - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
 
BufferBuilder - Class in com.hazelcast.client.impl.protocol.util
Builder for appending buffers that grows capacity as necessary.
BufferBuilder() - Constructor for class com.hazelcast.client.impl.protocol.util.BufferBuilder
Construct a buffer builder with a default growth increment of BufferBuilder.INITIAL_CAPACITY
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.nio
 
BufferObjectDataOutput - Interface in com.hazelcast.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
 
build() - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
build(ClassLoader) - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
build() - Method in interface com.hazelcast.config.ConfigBuilder
Builds Config object.
build() - Method in class com.hazelcast.config.ProbabilisticQuorumConfigBuilder
 
build() - Method in class com.hazelcast.config.QuorumConfigBuilder
 
build() - Method in class com.hazelcast.config.RecentlyActiveQuorumConfigBuilder
 
build() - Method in class com.hazelcast.config.XmlConfigBuilder
 
BUILD - Static variable in class com.hazelcast.instance.GeneratedBuildProperties
 
build() - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
 
build() - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
 
build() - Method in class com.hazelcast.map.impl.query.Query.QueryBuilder
 
build() - Method in class com.hazelcast.map.impl.query.Target.TargetBuilder
 
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.util.collection.InflatableSet.Builder
 
buildExecutorName(String) - Static method in class com.hazelcast.mapreduce.impl.MapReduceUtil
 
BuildInfo - Class in com.hazelcast.instance
 
BuildInfo(String, String, String, int, boolean, byte) - Constructor for class com.hazelcast.instance.BuildInfo
 
BuildInfo(String, String, String, int, boolean, byte, 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
 
BuiltInCacheMergePolicies - Enum in com.hazelcast.cache
Enum that represents all built-in CacheMergePolicy implementations.
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.util.concurrent
Busy spin strategy targeted at lowest possible latency.
BusySpinIdleStrategy() - Constructor for class com.hazelcast.util.concurrent.BusySpinIdleStrategy
 
byOrdinal(int) - Static method in enum com.hazelcast.mapreduce.impl.operation.RequestPartitionResult.ResultState
 
byOrdinal(int) - Static method in enum com.hazelcast.mapreduce.JobPartitionState.State
Deprecated.
Returns an processing state by its given ordinal
BYTE_ARRAY_ACCESS - Static variable in class com.hazelcast.internal.memory.impl.EndiannessUtil
Accesses bytes in a Java byte array
BYTE_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
BYTE_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
Deprecated.
 
BYTE_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
 
BYTE_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
Byte size in bytes
ByteAccessStrategy<R> - Interface in com.hazelcast.internal.memory
Access strategy for single memory bytes.
byteArray() - Method in interface com.hazelcast.client.impl.protocol.util.ClientProtocolBuffer
Get the underlying byte[] if one exists.
byteArray() - Method in class com.hazelcast.client.impl.protocol.util.SafeBuffer
 
byteArray() - Method in class com.hazelcast.client.impl.protocol.util.UnsafeBuffer
 
ByteArrayAccessStrategy - Class in com.hazelcast.internal.memory.impl
Implementation of ByteAccessStrategy for Java byte arrays.
ByteArrayProcessor - Interface in com.hazelcast.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
 
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
 
bytesToHex(byte[]) - Static method in class com.hazelcast.util.QuickMath
 
bytesToString(byte[], int, int) - Static method in class com.hazelcast.util.StringUtil
Creates a UTF8_CHARSET string from a byte array.
bytesToString(byte[]) - Static method in class com.hazelcast.util.StringUtil
Creates a UTF8_CHARSET string from a byte array.
bytesTransceived() - Method in class com.hazelcast.internal.networking.nio.NioThread
 

C

cache - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
cache - Variable in class com.hazelcast.cache.impl.operation.AbstractCacheOperation
 
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_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.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's 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
 
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
 
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
 
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
 
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
 
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<K,V> - Class in com.hazelcast.config
Contains all the configuration for the ICache.
CacheConfig() - Constructor for class com.hazelcast.config.CacheConfig
 
CacheConfig(String) - Constructor for class com.hazelcast.config.CacheConfig
 
CacheConfig(CompleteConfiguration<K, V>) - Constructor for class com.hazelcast.config.CacheConfig
 
CacheConfig(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheConfig
 
CacheConfigReadOnly<K,V> - Class in com.hazelcast.config
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
CacheConfiguration<K,V> - Interface in com.hazelcast.config
Mutable extension to CompleteConfiguration
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
 
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, com.hazelcast.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 - Enum in com.hazelcast.config
Control caching of de-serialized values.
CacheDestroyMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
 
CacheDestroyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
 
CacheDestroyOperation - Class in com.hazelcast.cache.impl.operation
Destroys the cache on the cluster or on a single node by calling ICacheService.deleteCache(String, String, boolean).
CacheDestroyOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheDestroyOperation
 
CacheDestroyOperation(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheDestroyOperation
 
CacheDestroyOperation(String, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheDestroyOperation
 
CachedExecutorServiceDelegate - Class in com.hazelcast.util.executor
 
CachedExecutorServiceDelegate(NodeEngine, String, ExecutorService, int, int) - Constructor for class com.hazelcast.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
 
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.
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.
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>>, Projection<? 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
 
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
 
CacheEventSet - Class in com.hazelcast.cache.impl
Internal Set wrapper of CacheEventData items used during publishing and dispatching events.
CacheEventSet() - Constructor for class com.hazelcast.cache.impl.CacheEventSet
 
CacheEventSet(CacheEventType, Set<CacheEventData>) - Constructor for class com.hazelcast.cache.impl.CacheEventSet
 
CacheEventSet(CacheEventType, Set<CacheEventData>, int) - Constructor for class com.hazelcast.cache.impl.CacheEventSet
 
CacheEventSet(CacheEventType, int) - Constructor for class com.hazelcast.cache.impl.CacheEventSet
 
CacheEventType - Enum in com.hazelcast.cache
Hazelcast JCache implementation's internal event types.
CacheEvictionConfig - Class in com.hazelcast.config
Deprecated.
Use EvictionConfig instead of this
CacheEvictionConfig() - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(int, EvictionConfig.MaxSizePolicy, EvictionPolicy) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(int, CacheEvictionConfig.CacheMaxSizePolicy, EvictionPolicy) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(int, EvictionConfig.MaxSizePolicy, String) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(int, CacheEvictionConfig.CacheMaxSizePolicy, String) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(int, EvictionConfig.MaxSizePolicy, EvictionPolicyComparator) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(int, CacheEvictionConfig.CacheMaxSizePolicy, EvictionPolicyComparator) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig(EvictionConfig) - Constructor for class com.hazelcast.config.CacheEvictionConfig
Deprecated.
 
CacheEvictionConfig.CacheMaxSizePolicy - Enum in com.hazelcast.config
Deprecated.
Cache Maximum Size Policy
CacheEvictionConfigReadOnly - Class in com.hazelcast.config
Deprecated.
Use EvictionConfigReadOnly instead of this
CacheEvictionConfigReadOnly(EvictionConfig) - Constructor for class com.hazelcast.config.CacheEvictionConfigReadOnly
Deprecated.
 
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
 
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
 
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
 
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
 
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
 
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
 
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
 
CacheLegacyMergeOperation - Class in com.hazelcast.cache.impl.operation
Contains a merging entry for split-brain healing with a CacheMergePolicy.
CacheLegacyMergeOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheLegacyMergeOperation
 
CacheLegacyMergeOperation(String, Data, CacheEntryView<Data, Data>, CacheMergePolicy) - Constructor for class com.hazelcast.cache.impl.operation.CacheLegacyMergeOperation
 
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
 
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